2025.06.13 15:31:42.449032 [ 421 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.06.13 15:31:42.450409 [ 421 ] {} Context: Server was built with undefined behavior sanitizer. It will work slowly. 2025.06.13 15:31:44.651306 [ 432 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' 2025.06.13 15:31:49.376613 [ 421 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.06.13 15:31:49.381462 [ 421 ] {} KeeperLogStore: Removing all changelogs 2025.06.13 15:31:49.455742 [ 421 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.06.13 15:31:49.469699 [ 421 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.06.13 15:31:49.470547 [ 421 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.06.13 15:31:49.530393 [ 1036 ] {} RaftInstance: Election timeout, initiate leader election 2025.06.13 15:31:50.361178 [ 421 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.06.13 15:31:50.362045 [ 421 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.06.13 15:31:50.488488 [ 421 ] {} 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.06.13 15:31:50.493840 [ 421 ] {} 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.06.13 15:32:09.042151 [ 425 ] {86d951bf-01aa-4194-b05c-a8c33ad1e5e8} 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.06.13 15:32:20.235707 [ 425 ] {b4f65742-f1e1-4bc6-bb85-61a5e11e341c} 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.06.13 15:32:33.093191 [ 1037 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.06.13 15:32:38.198497 [ 1372 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.06.13 15:32:38.199995 [ 1372 ] {} Context: Server was built with undefined behavior sanitizer. It will work slowly. 2025.06.13 15:32:39.768502 [ 1382 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' 2025.06.13 15:32:44.233734 [ 1372 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.06.13 15:32:44.251161 [ 1372 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.06.13 15:32:44.252066 [ 1372 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.06.13 15:32:44.331493 [ 1983 ] {} RaftInstance: Election timeout, initiate leader election 2025.06.13 15:32:45.977067 [ 1372 ] {} 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.06.13 15:32:45.982629 [ 1372 ] {} 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.06.13 15:33:44.773565 [ 1376 ] {b15211c8-e263-4ec2-b934-75b440046f45} executeQuery: Code: 241. DB::Exception: User memory limit exceeded: would use 9.18 GiB (attempt to allocate chunk of 1.29 MiB bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (avg_value_size_hint = 116.8260498046875, avg_chars_size = 130.59125976562498, limit = 8192): (while reading column Title): (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 1052 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60390) (query 1, line 1) (in query: INSERT INTO test.hits_s3 SELECT * FROM datasets.hits_v1 SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 9. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 11. ./src/Common/PODArray.h:221: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c66adea 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 31. ? @ 0x00007fef85568ac3 2025.06.13 15:33:53.897343 [ 1376 ] {} TCPHandler: Code: 241. DB::Exception: User memory limit exceeded: would use 9.18 GiB (attempt to allocate chunk of 1.29 MiB bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (avg_value_size_hint = 116.8260498046875, avg_chars_size = 130.59125976562498, limit = 8192): (while reading column Title): (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 1052 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 9. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 11. ./src/Common/PODArray.h:221: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c66adea 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 31. ? @ 0x00007fef85568ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007fef85568ac3 11. ? @ 0x00007fef855fa850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007fef85568ac3 12. ? @ 0x00007fef855fa850 2025.06.13 15:34:18.168609 [ 1376 ] {39949147-ef87-4d5b-b3d2-d64c3fa0168c} executeQuery: Code: 241. DB::Exception: User memory limit exceeded: would use 9.18 GiB (attempt to allocate chunk of 1.08 MiB bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49214) (query 1, line 1) (in query: INSERT INTO test.hits SELECT * FROM datasets.hits_v1 SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 9. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 10. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 11. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b684b1 12. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b683f6 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b67671 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023cffee2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c94d347 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c93f7d8 17. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030af5e0c 18. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030de515f 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e077b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0421c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030df7c14 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030df7634 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dcd49e 26. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c5a31b 27. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030feff3e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e43ccf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e3f751 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031229dad 31. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f67cf7 2025.06.13 15:34:22.629758 [ 1376 ] {} TCPHandler: Code: 241. DB::Exception: User memory limit exceeded: would use 9.18 GiB (attempt to allocate chunk of 1.08 MiB bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 9. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 10. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 11. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b684b1 12. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b683f6 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b67671 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023cffee2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c94d347 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c93f7d8 17. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030af5e0c 18. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000030de515f 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000030e077b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030e0421c 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030df7c14 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030df7634 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dcd49e 26. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c5a31b 27. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030feff3e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e43ccf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e3f751 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031229dad 31. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f67cf7 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181b22b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 11. ? @ 0x00007fef85568ac3 12. ? @ 0x00007fef855fa850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181b22b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 11. ? @ 0x00007fef85568ac3 12. ? @ 0x00007fef855fa850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007fef85568ac3 11. ? @ 0x00007fef855fa850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007fef85568ac3 12. ? @ 0x00007fef855fa850 2025.06.13 15:35:28.652066 [ 1376 ] {0871b246-10aa-4f67-bf27-e0c6014c3d67} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 65648.13531 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59976) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007fef85568ac3 14. ? @ 0x00007fef855fa850 2025.06.13 15:35:29.471324 [ 1376 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 65648.13531 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007fef85568ac3 14. ? @ 0x00007fef855fa850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007fef85568ac3 12. ? @ 0x00007fef855fa850 2025.06.13 15:35:33.968411 [ 2857 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.06.13 15:35:33.970008 [ 2857 ] {} Context: Server was built with undefined behavior sanitizer. It will work slowly. 2025.06.13 15:35:35.777663 [ 2868 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' 2025.06.13 15:35:39.492791 [ 2857 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.06.13 15:35:39.510674 [ 2857 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.06.13 15:35:39.511606 [ 2857 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.06.13 15:35:39.575025 [ 3463 ] {} RaftInstance: Election timeout, initiate leader election 2025.06.13 15:35:41.896810 [ 2857 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.06.13 15:35:41.898765 [ 2857 ] {} 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.06.13 15:35:41.905174 [ 2857 ] {} 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.06.13 15:36:15.122360 [ 4010 ] {0625fb9d-a638-4992-a336-5ff380e6909b} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39892) (comment: 01825_type_json_describe.sql) (query 1, line 3) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:36:15.158917 [ 4010 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:36:15.859041 [ 2861 ] {beea3937-9d9b-4835-8ca5-329979596a80} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57186) (comment: 02941_projections_external_aggregation.sql) (query 10, line 34) (in query: SELECT k1, k2, k3, sum(value) v FROM t_proj_external GROUP BY k1, k2, k3 ORDER BY k1, k2, k3;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f585dc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f5af07 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c6608d1 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f54898 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f54302 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dd53bf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dcd2b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 2025.06.13 15:36:15.906342 [ 2861 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f585dc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f5af07 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c6608d1 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f54898 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f54302 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dd53bf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dcd2b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:36:16.700403 [ 2862 ] {cc1ca887-fc8f-4fb8-8676-ef9ac00c1e8c} executeQuery: Code: 43. DB::Exception: Second argument of function fuzzBits must be constant float: In scope SELECT fuzzBits(toString('string'), 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39926) (comment: 01284_fuzz_bits.sql) (query 1, line 1) (in query: SELECT fuzzBits(toString('string'), 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionFuzzBits::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ae61723 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:16.714153 [ 2862 ] {} TCPHandler: Code: 43. DB::Exception: Second argument of function fuzzBits must be constant float: In scope SELECT fuzzBits(toString('string'), 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionFuzzBits::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ae61723 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:16.955674 [ 2862 ] {a4797038-06a5-49c6-89fd-9f91f96558cf} executeQuery: Code: 69. DB::Exception: Second argument of function fuzzBits must be from `0.0` to `1.0`: In scope SELECT fuzzBits('string', -1.). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39926) (comment: 01284_fuzz_bits.sql) (query 2, line 2) (in query: SELECT fuzzBits('string', -1.0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionFuzzBits::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae60b6a 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:36:16.963517 [ 2862 ] {} TCPHandler: Code: 69. DB::Exception: Second argument of function fuzzBits must be from `0.0` to `1.0`: In scope SELECT fuzzBits('string', -1.). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionFuzzBits::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae60b6a 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:36:18.991753 [ 3838 ] {d06febbb-9c9b-4e40-a1c5-08dd6d7f2b92} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39994) (comment: 00855_join_with_array_join.sql) (query 6, line 7) (in query: SELECT ax, c, d FROM (SELECT [7,8] ax, 1 c, 0 d) s1 JOIN system.one s2 ON s1.c = s2.dummy OR s1.d = s2.dummy ARRAY JOIN ax;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf46bd 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddaedfc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: DB::(anonymous namespace)::buildQueryPlanForJoinNodeLegacy(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddac1bc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd98170 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:19.020320 [ 3838 ] {} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf46bd 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddaedfc 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: DB::(anonymous namespace)::buildQueryPlanForJoinNodeLegacy(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddac1bc 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd98170 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:20.162115 [ 4163 ] {0bdbb88f-20b1-4a68-9545-b7c39c113dd5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=770). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39950) (comment: 00147_alter_nested_default.sql) (query 15, line 22) (in query: SELECT * FROM alter_00147 ARRAY JOIN n WHERE n.x LIKE '%Hello%' ORDER BY n.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:36:20.169882 [ 4163 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=770). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:36:20.434248 [ 3837 ] {1ffa8df5-6501-42bc-a71f-89aa37f03b8d} AsynchronousInsertQueue: Setting 'async_insert_busy_timeout_min_ms'=500 is greater than 'async_insert_busy_timeout_max_ms'=100. Ignoring 'async_insert_busy_timeout_min_ms' 2025.06.13 15:36:20.782683 [ 3837 ] {d7ad2396-e8de-4b91-9043-3015a094fd17} executeQuery: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_increase_rate' must be greater than zero. (INVALID_SETTING_VALUE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40006) (comment: 02968_adaptive_async_insert_timeout.sql) (query 7, line 35) (in query: INSERT INTO async_insert_mt_test SETTINGS async_insert=1, wait_for_async_insert=1, async_insert_busy_timeout_increase_rate=-1.0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:610: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000002d3f91c7 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:424: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002d3f63bf 7. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f5ecf 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:36:20.797302 [ 3837 ] {} TCPHandler: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_increase_rate' must be greater than zero. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:610: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000002d3f91c7 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:424: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002d3f63bf 7. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f5ecf 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:36:21.179091 [ 3837 ] {bd8f4db6-53b2-4da7-a3a8-5c1816f4a992} executeQuery: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_decrease_rate' must be greater than zero. (INVALID_SETTING_VALUE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40006) (comment: 02968_adaptive_async_insert_timeout.sql) (query 8, line 43) (in query: INSERT INTO async_insert_mt_test SETTINGS async_insert=1, wait_for_async_insert=1, async_insert_busy_timeout_decrease_rate=-1.0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:613: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000002d3f9243 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:424: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002d3f63bf 7. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f5ecf 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:36:21.188758 [ 3837 ] {} TCPHandler: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_decrease_rate' must be greater than zero. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:613: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000002d3f9243 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:424: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002d3f63bf 7. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f5ecf 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:36:21.868356 [ 3894 ] {a94fc1ac-61af-4e3f-820e-ceb10e56075e} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40122) (comment: 01635_sum_map_fuzz.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: DB::registerAggregateFunctionSumMap(DB::AggregateFunctionFactory&)::$_3::operator()(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) const @ 0x0000000026aafc01 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:21.875482 [ 3894 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: DB::registerAggregateFunctionSumMap(DB::AggregateFunctionFactory&)::$_3::operator()(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) const @ 0x0000000026aafc01 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:22.323818 [ 3829 ] {576d50ff-de62-4b69-ada0-c8ae16372370} 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.20286.altinityantalya (altinity build)) (from [::1]:39874) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionReinterpret::getReturnTypeImpl(std::vector> const&) const @ 0x000000002063bc87 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:22.328937 [ 3829 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionReinterpret::getReturnTypeImpl(std::vector> const&) const @ 0x000000002063bc87 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:22.602851 [ 3894 ] {c00fff0e-9435-411a-8b0f-da68bec1e8b1} 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.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 03304_compare_substrings.sql) (query 1, line 1) (in query: -- Negative tests -- Five arguments are expected select compareSubstrings();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:36:22.612129 [ 3894 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 0 arguments: In scope SELECT compareSubstrings(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:36:22.838412 [ 3894 ] {074edcb0-e3b8-4385-9fd8-eba9bc652ad6} 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.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 03304_compare_substrings.sql) (query 2, line 5) (in query: select compareSubstrings('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:36:22.844452 [ 3894 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 1 argument: In scope SELECT compareSubstrings('abc'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:36:22.959048 [ 3894 ] {d5d5d5cc-6388-472b-a1f2-532c4128bbcc} 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.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 03304_compare_substrings.sql) (query 3, line 6) (in query: select compareSubstrings('abc', 'abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:36:22.965629 [ 3894 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 2 arguments: In scope SELECT compareSubstrings('abc', 'abc'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:36:23.046167 [ 3894 ] {7d44fc6a-da0c-4a8c-978f-3fff4358e094} 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.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 03304_compare_substrings.sql) (query 4, line 7) (in query: select compareSubstrings('abc', 'abc', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:36:23.078600 [ 3894 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 3 arguments: In scope SELECT compareSubstrings('abc', 'abc', 0). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:36:23.178069 [ 3894 ] {592bb326-5f5c-48ab-9c63-837aabadb0dd} 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.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 03304_compare_substrings.sql) (query 5, line 8) (in query: select compareSubstrings('abc', 'abc', 0, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:36:23.185232 [ 3894 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 4 arguments: In scope SELECT compareSubstrings('abc', 'abc', 0, 0). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:36:23.266267 [ 3894 ] {3fc6132a-2412-4118-8deb-e1fbd778f239} 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.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 03304_compare_substrings.sql) (query 6, line 9) (in query: select compareSubstrings('abc', 'abc', 0, 0, 0, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:36:23.284727 [ 3894 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 6 arguments: In scope SELECT compareSubstrings('abc', 'abc', 0, 0, 0, 0). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:36:23.539261 [ 4171 ] {a1763c94-0278-47ae-b1e2-e218f062bcf1} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `number` in scope SELECT arrayFilter(x -> notEmpty(concat(x, 'hello')), ['']) FROM system.one ARRAY JOIN [0] AS elem, arrayMap(x -> concat(x, ignore(ignore(toLowCardinality('03147_parquet_memory_tracking.parquet'), 37, 37, toUInt128(37), 37, 37, toLowCardinality(37), 37), 8, ignore(ignore(1., 36, 8, 8)), *), 'hello'), ['']) AS unused WHERE NOT ignore(elem) GROUP BY sum(ignore(ignore(ignore(1., 1, 36, 8, 8), ignore(52, 37, 37, '03147_parquet_memory_tracking.parquet', 37, 37, toUInt256(37), 37, 37, toNullable(37), 37, 37), 1., 1, 36, 8, 8), emptyArrayToSingle(arrayMap(x -> toString(x), arrayMap(x -> nullIf(x, 2), arrayJoin([[1]])))))) IGNORE NULLS, modulo(toLowCardinality('03147_parquet_memory_tracking.parquet'), number, toLowCardinality(3)). (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39958) (comment: 02374_analyzer_array_join.sql) (query 32, line 70) (in query: SELECT arrayFilter(x -> notEmpty(concat(x, 'hello')), ['']) FROM system.one ARRAY JOIN [0] AS elem, arrayMap(x -> concat(x, ignore(ignore(toLowCardinality('03147_parquet_memory_tracking.parquet'), 37, 37, toUInt128(37), 37, 37, toLowCardinality(37), 37), 8, ignore(ignore(1., 36, 8, 8)), *), 'hello'), ['']) AS unused WHERE NOT ignore(elem) GROUP BY sum(ignore(ignore(ignore(1., 1, 36, 8, 8), ignore(52, 37, 37, '03147_parquet_memory_tracking.parquet', 37, 37, toUInt256(37), 37, 37, toNullable(37), 37, 37), 1., 1, 36, 8, 8), emptyArrayToSingle(arrayMap(x -> toString(x), arrayMap(x -> nullIf(x, 2), arrayJoin([[1]])))))) IGNORE NULLS, modulo(toLowCardinality('03147_parquet_memory_tracking.parquet'), number, toLowCardinality(3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4227: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x000000002cc49279 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9df5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:36:23.549237 [ 4171 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `number` in scope SELECT arrayFilter(x -> notEmpty(concat(x, 'hello')), ['']) FROM system.one ARRAY JOIN [0] AS elem, arrayMap(x -> concat(x, ignore(ignore(toLowCardinality('03147_parquet_memory_tracking.parquet'), 37, 37, toUInt128(37), 37, 37, toLowCardinality(37), 37), 8, ignore(ignore(1., 36, 8, 8)), *), 'hello'), ['']) AS unused WHERE NOT ignore(elem) GROUP BY sum(ignore(ignore(ignore(1., 1, 36, 8, 8), ignore(52, 37, 37, '03147_parquet_memory_tracking.parquet', 37, 37, toUInt256(37), 37, 37, toNullable(37), 37, 37), 1., 1, 36, 8, 8), emptyArrayToSingle(arrayMap(x -> toString(x), arrayMap(x -> nullIf(x, 2), arrayJoin([[1]])))))) IGNORE NULLS, modulo(toLowCardinality('03147_parquet_memory_tracking.parquet'), number, toLowCardinality(3)). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4227: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x000000002cc49279 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9df5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:36:23.558470 [ 3894 ] {27ef9312-1d41-48ef-8750-4c94490b534c} 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.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 03304_compare_substrings.sql) (query 7, line 11) (in query: -- 1st/2nd argument must be string, 3rd/4th/5th argument must be integer select compareSubstrings(0, 'abc', 0, 0, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:23.564082 [ 3894 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string1' to function 'compareSubstrings'. Expected: String, got: UInt8: In scope SELECT compareSubstrings(0, 'abc', 0, 0, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:23.622159 [ 3821 ] {a69fd3f6-9ef7-48ed-844f-2d054ebc643b} Context: Server has databases (for example `ordinary_test_9`) 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.06.13 15:36:23.696441 [ 3894 ] {bbe8570e-75d5-42e7-a5eb-6259d07fa480} 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.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 03304_compare_substrings.sql) (query 8, line 13) (in query: select compareSubstrings('abc', 0, 0, 0, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:23.703997 [ 3894 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'string2' to function 'compareSubstrings'. Expected: String, got: UInt8: In scope SELECT compareSubstrings('abc', 0, 0, 0, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:23.771526 [ 3894 ] {07ff8894-b7c2-424b-a68b-21016cac5205} 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.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 03304_compare_substrings.sql) (query 9, line 14) (in query: select compareSubstrings('abc', 'abc', 'abc', 0, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:23.791774 [ 3894 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'string1_offset' to function 'compareSubstrings'. Expected: const UInt*, got: String: In scope SELECT compareSubstrings('abc', 'abc', 'abc', 0, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:23.893020 [ 3894 ] {f6d5cb2f-eef8-4aee-9e34-88039ad40ebd} 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.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 03304_compare_substrings.sql) (query 10, line 15) (in query: select compareSubstrings('abc', 'abc', 0, 'abc', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:23.906205 [ 3894 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'string2_offset' to function 'compareSubstrings'. Expected: const UInt*, got: String: In scope SELECT compareSubstrings('abc', 'abc', 0, 'abc', 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:24.042649 [ 3894 ] {0614a64b-1a01-48e8-949b-3e1677cfda8c} 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.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 03304_compare_substrings.sql) (query 11, line 16) (in query: select compareSubstrings('abc', 'abc', 0, 0, 'abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:24.051339 [ 3894 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'num_bytes' to function 'compareSubstrings'. Expected: const UInt*, got: String: In scope SELECT compareSubstrings('abc', 'abc', 0, 0, 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:24.184287 [ 3894 ] {3b2f6ad6-0a1b-4bc2-bdc9-f41f87efe396} 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.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 03304_compare_substrings.sql) (query 12, line 18) (in query: -- 3rd, 4th, 5th argument must be non-negative select compareSubstrings('abc', 'abc', -1, 0, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:24.194845 [ 3894 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'string1_offset' to function 'compareSubstrings'. Expected: const UInt*, got: Int8: In scope SELECT compareSubstrings('abc', 'abc', -1, 0, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:24.273893 [ 3894 ] {6a8b090e-53f1-4f7a-8108-0cb1a7f63d23} 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.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 03304_compare_substrings.sql) (query 13, line 20) (in query: select compareSubstrings('abc', 'abc', 0, -1, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:24.289645 [ 3894 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'string2_offset' to function 'compareSubstrings'. Expected: const UInt*, got: Int8: In scope SELECT compareSubstrings('abc', 'abc', 0, -1, 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:24.467882 [ 3894 ] {0b34db91-de78-4e68-8abb-962578f77dd3} 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.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 03304_compare_substrings.sql) (query 14, line 21) (in query: select compareSubstrings('abc', 'abc', 0, 0, -1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:24.484240 [ 3894 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'num_bytes' to function 'compareSubstrings'. Expected: const UInt*, got: Int8: In scope SELECT compareSubstrings('abc', 'abc', 0, 0, -1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionCompareSubstrings::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019eee1f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:25.466665 [ 3829 ] {0a99f1c3-b337-4aa9-bfaf-8176bddc7471} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: +, error: no argument for repetition operator: +. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('+', 'a+b+c'). (CANNOT_COMPILE_REGEXP) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40180) (comment: 01866_split_by_regexp.sql) (query 12, line 13) (in query: select splitByRegexp('+', 'a+b+c');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023aba574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002086ffeb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceba06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:25.470327 [ 3829 ] {} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: +, error: no argument for repetition operator: +. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('+', 'a+b+c'). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023aba574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002086ffeb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceba06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:25.600043 [ 3829 ] {c11d7cef-90d8-4ae7-8d5b-6b83cdd25e74} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: ?, error: no argument for repetition operator: ?. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('?', 'a?b?c'). (CANNOT_COMPILE_REGEXP) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40180) (comment: 01866_split_by_regexp.sql) (query 13, line 14) (in query: select splitByRegexp('?', 'a?b?c');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023aba574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002086ffeb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceba06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:25.610964 [ 3829 ] {} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: ?, error: no argument for repetition operator: ?. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('?', 'a?b?c'). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023aba574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002086ffeb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceba06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:25.713578 [ 3829 ] {045c377b-c2c7-4d61-9999-31c0928903aa} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (, error: missing ): (. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('(', 'a(b(c'). (CANNOT_COMPILE_REGEXP) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40180) (comment: 01866_split_by_regexp.sql) (query 14, line 15) (in query: select splitByRegexp('(', 'a(b(c');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023aba574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002086ffeb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceba06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:25.728066 [ 3829 ] {} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (, error: missing ): (. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('(', 'a(b(c'). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023aba574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002086ffeb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceba06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:26.151786 [ 3829 ] {ff14f187-fd88-49c8-ab19-2bd4a767dfef} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: [, error: missing ]: [. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('[', 'a[b[c'). (CANNOT_COMPILE_REGEXP) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40180) (comment: 01866_split_by_regexp.sql) (query 16, line 17) (in query: select splitByRegexp('[', 'a[b[c');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023aba574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002086ffeb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceba06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:26.166266 [ 3829 ] {} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: [, error: missing ]: [. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('[', 'a[b[c'). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000023aba574 6. DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000002086ffeb 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceba06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:26.348094 [ 4969 ] {d64988f3-a2af-4ead-9018-fd5df5b69bc3} 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.06.13 15:36:27.413001 [ 2861 ] {68698eed-1594-4517-8350-ab8581782f5b} executeQuery: Code: 42. DB::Exception: Array data type family must have exactly one argument - type of elements: In scope SELECT CAST(0, 'Array'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36508) (comment: 00540_bad_data_types.sh) (query 1, line 1) (in query: SELECT CAST(0 AS Array)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:102: DB::create(std::shared_ptr const&) @ 0x000000002c3f95b6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:36:27.440044 [ 2861 ] {} TCPHandler: Code: 42. DB::Exception: Array data type family must have exactly one argument - type of elements: In scope SELECT CAST(0, 'Array'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/DataTypes/DataTypeArray.cpp:102: DB::create(std::shared_ptr const&) @ 0x000000002c3f95b6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:36:27.899492 [ 3829 ] {1126ea7f-8f01-4b4f-b79f-6ec9bb8f1f74} executeQuery: Code: 44. DB::Exception: Argument at index 0 for function splitByRegexp must be constant. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40180) (comment: 01866_split_by_regexp.sql) (query 23, line 25) (in query: SELECT splitByRegexp(materialize(1), NULL, 3) -- { serverError ILLEGAL_COLUMN } ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb202f 5. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace52eb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 14. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:36:27.924779 [ 3829 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 0 for function splitByRegexp must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb202f 5. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace52eb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 14. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:36:28.135557 [ 2861 ] {a9283476-fb03-4a88-81d9-a68a9d7ab3ff} executeQuery: Code: 42. DB::Exception: Data type AggregateFunction requires parameters: version(optionally), name of aggregate function and list of data types for arguments: In scope SELECT CAST(0, 'AggregateFunction'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36526) (comment: 00540_bad_data_types.sh) (query 1, line 1) (in query: SELECT CAST(0 AS AggregateFunction)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/DataTypes/DataTypeAggregateFunction.cpp:209: DB::create(std::shared_ptr const&) @ 0x000000002c3f4d1d 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:36:28.206749 [ 2861 ] {} TCPHandler: Code: 42. DB::Exception: Data type AggregateFunction requires parameters: version(optionally), name of aggregate function and list of data types for arguments: In scope SELECT CAST(0, 'AggregateFunction'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/DataTypes/DataTypeAggregateFunction.cpp:209: DB::create(std::shared_ptr const&) @ 0x000000002c3f4d1d 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:36:28.686159 [ 4969 ] {3c004793-0e66-4065-81bc-6acb16c18753} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36488) (comment: 02980_s3_plain_DROP_TABLE_MergeTree.sh) (query 4, line 12) (in query: insert into data values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2756: DB::StorageMergeTree::assertNotReadonly() const @ 0x00000000311cb72e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:341: DB::StorageMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000311cb502 7. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031ef648f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dcdd134 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dcdf787 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dce393d 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5e89 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:28.708978 [ 4969 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2756: DB::StorageMergeTree::assertNotReadonly() const @ 0x00000000311cb72e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:341: DB::StorageMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000311cb502 7. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031ef648f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dcdd134 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dcdf787 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dce393d 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5e89 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:28.940952 [ 4969 ] {750520a5-3816-4ffc-9c62-2391f3100f8b} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36488) (comment: 02980_s3_plain_DROP_TABLE_MergeTree.sh) (query 5, line 13) (in query: optimize table data final;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2756: DB::StorageMergeTree::assertNotReadonly() const @ 0x00000000311cb72e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1645: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e87b5 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:36:28.941194 [ 2862 ] {4705bb2f-ba97-410b-a0e7-e512531d98d6} executeQuery: Code: 42. DB::Exception: Nullable data type family must have exactly one argument - nested type: In scope SELECT CAST(0, 'Nullable'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36544) (comment: 00540_bad_data_types.sh) (query 1, line 1) (in query: SELECT CAST(0 AS Nullable)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:122: DB::create(std::shared_ptr const&) @ 0x000000002c43ed96 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:36:28.954365 [ 4969 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:2756: DB::StorageMergeTree::assertNotReadonly() const @ 0x00000000311cb72e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1645: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e87b5 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:36:28.967673 [ 2862 ] {} TCPHandler: Code: 42. DB::Exception: Nullable data type family must have exactly one argument - nested type: In scope SELECT CAST(0, 'Nullable'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:122: DB::create(std::shared_ptr const&) @ 0x000000002c43ed96 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:36:29.741352 [ 4163 ] {f4e31521-a8ca-4c3b-90fb-f8f40234d6a4} executeQuery: Code: 53. DB::Exception: CAST AS Tuple can only be performed between tuple types or from String. Left type: UInt8, right type: Tuple(): In scope SELECT CAST(0, 'Tuple'). (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36570) (comment: 00540_bad_data_types.sh) (query 1, line 1) (in query: SELECT CAST(0 AS Tuple)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::detail::FunctionCast::createTupleWrapper(std::shared_ptr const&, DB::DataTypeTuple const*) const @ 0x000000002ada12b4 6. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad9e506 7. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad80a2d 8. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad7eb8d 9. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad7db23 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3557: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc30615 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:29.775711 [ 4163 ] {} TCPHandler: Code: 53. DB::Exception: CAST AS Tuple can only be performed between tuple types or from String. Left type: UInt8, right type: Tuple(): In scope SELECT CAST(0, 'Tuple'). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::detail::FunctionCast::createTupleWrapper(std::shared_ptr const&, DB::DataTypeTuple const*) const @ 0x000000002ada12b4 6. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad9e506 7. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002ad80a2d 8. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad7eb8d 9. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad7db23 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3557: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc30615 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:30.372885 [ 4969 ] {376f8e1a-6ea4-440f-9b20-17865a2bae7f} executeQuery: Code: 42. DB::Exception: FixedString data type family must have exactly one argument - size in bytes: In scope SELECT CAST(0, 'FixedString'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36608) (comment: 00540_bad_data_types.sh) (query 1, line 1) (in query: SELECT CAST(0 AS FixedString)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/DataTypes/DataTypeFixedString.cpp:60: DB::create(std::shared_ptr const&) @ 0x000000002c423e6b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:36:30.411575 [ 4969 ] {} TCPHandler: Code: 42. DB::Exception: FixedString data type family must have exactly one argument - size in bytes: In scope SELECT CAST(0, 'FixedString'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/DataTypes/DataTypeFixedString.cpp:60: DB::create(std::shared_ptr const&) @ 0x000000002c423e6b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:36:31.058320 [ 5005 ] {b6396be6-9f91-49c1-8d52-9f637b17e034} executeQuery: Code: 92. DB::Exception: Enum data type cannot be empty: In scope SELECT CAST(0, 'Enum'). (EMPTY_DATA_PASSED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36644) (comment: 00540_bad_data_types.sh) (query 1, line 1) (in query: SELECT CAST(0 AS Enum)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:283: DB::create(std::shared_ptr const&) @ 0x000000002c40ff6e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:36:31.078133 [ 5005 ] {} TCPHandler: Code: 92. DB::Exception: Enum data type cannot be empty: In scope SELECT CAST(0, 'Enum'). (EMPTY_DATA_PASSED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:283: DB::create(std::shared_ptr const&) @ 0x000000002c40ff6e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:36:31.222695 [ 4969 ] {4855c592-fcd7-41f1-b6e8-5ec098185acc} executeQuery: Code: 53. DB::Exception: ARRAY JOIN (SELECT 1 AS c0 FROM system.one LIMIT _CAST(0, 'UInt64') BY) AS t0 ARRAY JOIN t0.c0 requires expression t0.c0 with Array or Map type. Actual UInt8. In scope SELECT 1 FROM (SELECT 1 AS c0 LIMIT 0 BY COLUMNS('1')) AS t0 ARRAY JOIN c0. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36630) (comment: 03290_limit_by_segv.sql) (query 1, line 1) (in query: SELECT 1 FROM (SELECT 1 AS c0 LIMIT 0 BY COLUMNS('1')) t0 ARRAY JOIN c0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5023: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000002cc51176 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5077: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4f56f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5333: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc35 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:36:31.238205 [ 4969 ] {} TCPHandler: Code: 53. DB::Exception: ARRAY JOIN (SELECT 1 AS c0 FROM system.one LIMIT _CAST(0, 'UInt64') BY) AS t0 ARRAY JOIN t0.c0 requires expression t0.c0 with Array or Map type. Actual UInt8. In scope SELECT 1 FROM (SELECT 1 AS c0 LIMIT 0 BY COLUMNS('1')) AS t0 ARRAY JOIN c0. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5023: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&)::$_0::operator()(std::shared_ptr const&) const @ 0x000000002cc51176 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5077: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4f56f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5333: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc35 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:36:32.371632 [ 3829 ] {e776d836-2162-43ac-a923-70e2f5d60b5b} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT * FROM system.one WHERE toString(dummy). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36706) (comment: 00540_bad_data_types.sh) (query 1, line 1) (in query: SELECT * FROM system.one WHERE toString(dummy)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09140f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cc964cd 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cc96058 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0bf 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:36:32.398326 [ 3829 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT * FROM system.one WHERE toString(dummy). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09140f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cc964cd 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cc96058 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0bf 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:36:32.430435 [ 4171 ] {c8f69af0-16c0-484c-87e2-08209425d739} executeQuery: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (value) using identifier 'value' cannot be resolved from left table expression. In scope SELECT * FROM v1 AS t1 INNER JOIN v1 AS t2 USING (id) INNER JOIN v1 AS t3 USING (value). (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36496) (comment: 01852_multiple_joins_with_union_join.sql) (query 10, line 22) (in query: SELECT * FROM v1 AS t1 JOIN v1 AS t2 USING (id) JOIN v1 AS t3 USING (value);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000002cc5bacf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc56579 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:36:32.443706 [ 4171 ] {} TCPHandler: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (value) using identifier 'value' cannot be resolved from left table expression. In scope SELECT * FROM v1 AS t1 INNER JOIN v1 AS t2 USING (id) INNER JOIN v1 AS t3 USING (value). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000002cc5bacf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc56579 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:36:32.923460 [ 5110 ] {40d12208-c144-44d7-b37f-61383760c4c6} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT * FROM system.one WHERE toString(1). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36720) (comment: 00540_bad_data_types.sh) (query 1, line 1) (in query: SELECT * FROM system.one WHERE toString(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09140f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cc964cd 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cc96058 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0bf 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:36:32.964743 [ 5110 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT * FROM system.one WHERE toString(1). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09140f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cc964cd 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cc96058 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0bf 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:36:33.740270 [ 5163 ] {d82c59e8-cf2e-47dc-a48b-d91ba86d5aff} executeQuery: Code: 59. DB::Exception: Illegal type UInt16 of column for constant filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51542) (comment: 00540_bad_data_types.sh) (query 1, line 1) (in query: SELECT * FROM system.one WHERE 256), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Columns/FilterDescription.cpp:39: DB::ConstantFilterDescription::ConstantFilterDescription(DB::IColumn const&) @ 0x0000000030224320 6. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:58: DB::(anonymous namespace)::analyzeFilter(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::ActionsChain&) @ 0x000000002de033b6 7. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:558: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002ddfc704 8. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6eedb 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:36:33.764197 [ 5163 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type UInt16 of column for constant filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Columns/FilterDescription.cpp:39: DB::ConstantFilterDescription::ConstantFilterDescription(DB::IColumn const&) @ 0x0000000030224320 6. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:58: DB::(anonymous namespace)::analyzeFilter(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::ActionsChain&) @ 0x000000002de033b6 7. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:558: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002ddfc704 8. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6eedb 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:36:34.286483 [ 4171 ] {fbe4aae6-6d6b-4155-9c6c-a509f1d15350} executeQuery: Code: 59. DB::Exception: Illegal type Int8 of column for constant filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51558) (comment: 00540_bad_data_types.sh) (query 1, line 1) (in query: SELECT * FROM system.one WHERE -1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Columns/FilterDescription.cpp:39: DB::ConstantFilterDescription::ConstantFilterDescription(DB::IColumn const&) @ 0x0000000030224320 6. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:58: DB::(anonymous namespace)::analyzeFilter(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::ActionsChain&) @ 0x000000002de033b6 7. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:558: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002ddfc704 8. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6eedb 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:36:34.318932 [ 4171 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type Int8 of column for constant filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Columns/FilterDescription.cpp:39: DB::ConstantFilterDescription::ConstantFilterDescription(DB::IColumn const&) @ 0x0000000030224320 6. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:58: DB::(anonymous namespace)::analyzeFilter(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::ActionsChain&) @ 0x000000002de033b6 7. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:558: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002ddfc704 8. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6eedb 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:36:34.938644 [ 5005 ] {7e4ce83a-06c0-46a3-8a64-6cbee23326ac} executeQuery: Code: 59. DB::Exception: Illegal type Nullable(UInt16) of column for constant filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51592) (comment: 00540_bad_data_types.sh) (query 1, line 1) (in query: SELECT * FROM system.one WHERE CAST(256 AS Nullable(UInt16))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Columns/FilterDescription.cpp:39: DB::ConstantFilterDescription::ConstantFilterDescription(DB::IColumn const&) @ 0x0000000030224320 6. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:58: DB::(anonymous namespace)::analyzeFilter(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::ActionsChain&) @ 0x000000002de033b6 7. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:558: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002ddfc704 8. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6eedb 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:36:34.949006 [ 5005 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type Nullable(UInt16) of column for constant filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Columns/FilterDescription.cpp:39: DB::ConstantFilterDescription::ConstantFilterDescription(DB::IColumn const&) @ 0x0000000030224320 6. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:58: DB::(anonymous namespace)::analyzeFilter(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::ActionsChain&) @ 0x000000002de033b6 7. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:558: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002ddfc704 8. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6eedb 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:36:35.436197 [ 4171 ] {434b449b-54a9-4470-b264-a28990c41b63} executeQuery: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51570) (comment: 01880_remote_ipv6.sql) (query 4, line 6) (in query: SELECT * FROM remote('[::1', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Common/parseAddress.cpp:28: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0020 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:35.443906 [ 4171 ] {} TCPHandler: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Common/parseAddress.cpp:28: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0020 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:35.547061 [ 4172 ] {e96395bb-059d-4583-b0f5-6b87a9b18b69} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=794, jobs=778): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40044) (comment: 03036_recursive_cte_postgres_2.sql) (query 16, line 116) (in query: -- inside subqueries SELECT count(*) FROM ( WITH RECURSIVE t AS ( SELECT toUInt64(1) AS n UNION ALL SELECT n + 1 FROM t WHERE n < 500 ) SELECT * FROM t ) AS t WHERE n < ( SELECT count(*) FROM ( WITH RECURSIVE t AS ( SELECT toUInt64(1) AS n UNION ALL SELECT n + 1 FROM t WHERE n < 100 ) SELECT * FROM t WHERE n < 50000 ) AS t WHERE n < 100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:134: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003222beeb 9. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x000000003222bc62 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:36:35.581162 [ 4171 ] {18b911c9-3878-403a-81b4-cc0f4d2d12c9} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51570) (comment: 01880_remote_ipv6.sql) (query 5, line 7) (in query: SELECT * FROM remote('::1]', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0295 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:35.602011 [ 4171 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0295 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:35.602125 [ 4172 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=794, jobs=778): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:134: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003222beeb 9. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x000000003222bc62 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:36:35.669687 [ 4171 ] {f262f7f5-a431-441d-97f5-51b05daddebf} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51570) (comment: 01880_remote_ipv6.sql) (query 6, line 8) (in query: SELECT * FROM remote('::1', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0295 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:35.690998 [ 4171 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0295 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:35.864036 [ 4171 ] {3c1dba43-7e0f-425e-974f-9ed0d9529762} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1]. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51570) (comment: 01880_remote_ipv6.sql) (query 7, line 10) (in query: SELECT * FROM remote('[::1][::1]', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0175 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:35.877724 [ 4171 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0175 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:35.966030 [ 4171 ] {38e22d47-2aa1-460a-a5af-ffa6b8ef7049} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51570) (comment: 01880_remote_ipv6.sql) (query 8, line 11) (in query: SELECT * FROM remote('[::1][::1', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0175 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:35.977589 [ 4171 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0175 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:36.065500 [ 4171 ] {1716ad07-24ea-48fd-823b-651d06ab0ee1} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51570) (comment: 01880_remote_ipv6.sql) (query 9, line 12) (in query: SELECT * FROM remote('[::1]::1]', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0295 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:36.074761 [ 4171 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0295 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:36.360847 [ 3894 ] {0190df06-6434-41d4-8ab1-aa52fe3a1093} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.41 MiB (attempt to allocate chunk of 1.41 MiB bytes), maximum: 976.56 KiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51612) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_5.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b62c7e 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:121: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x0000000023caba8f 12. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x0000000023cabe55 13. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003149de21 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003149ddce 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, Poco::Net::StreamSocket&) @ 0x0000000031494f1e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], Poco::Net::StreamSocket&, 0>(std::allocator const&, Poco::Net::StreamSocket&) @ 0x0000000031494d7a 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x0000000031474c84 18. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003147f18d 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314a4c99 20. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000314a7804 21. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 22. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 24. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:36:36.393372 [ 3894 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.41 MiB (attempt to allocate chunk of 1.41 MiB bytes), maximum: 976.56 KiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b62c7e 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:121: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x0000000023caba8f 12. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x0000000023cabe55 13. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003149de21 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003149ddce 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, Poco::Net::StreamSocket&) @ 0x0000000031494f1e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], Poco::Net::StreamSocket&, 0>(std::allocator const&, Poco::Net::StreamSocket&) @ 0x0000000031494d7a 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x0000000031474c84 18. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003147f18d 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314a4c99 20. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000314a7804 21. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 22. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 24. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:36:36.706074 [ 4171 ] {5f508b9d-ba26-4eb5-9689-7691e513ce63} executeQuery: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51570) (comment: 01880_remote_ipv6.sql) (query 12, line 17) (in query: SELECT * FROM remote('[::1') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Common/parseAddress.cpp:28: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0020 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:36.714940 [ 4171 ] {} TCPHandler: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Common/parseAddress.cpp:28: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0020 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:36.779198 [ 4171 ] {964d7b5c-ff4e-4c06-ba8c-5ba593da352a} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51570) (comment: 01880_remote_ipv6.sql) (query 13, line 18) (in query: SELECT * FROM remote('::1]') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0295 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:36.785619 [ 4171 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0295 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:36.957130 [ 4171 ] {f6e1340f-9796-42e7-ab69-af53c093db75} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51570) (comment: 01880_remote_ipv6.sql) (query 14, line 19) (in query: SELECT * FROM remote('::1') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0295 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:36.968248 [ 4171 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0295 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:36.982644 [ 4107 ] {c59eba09-7f2a-45ea-b134-0c920aaa7d58} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 1.43 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51656) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_5.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b684b1 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:184: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x0000000023caff0f 12. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x0000000023cb0455 13. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x00000000314982fa 14. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x00000000314982ae 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, Poco::Net::StreamSocket&) @ 0x000000003149559e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], Poco::Net::StreamSocket&, 0>(std::allocator const&, Poco::Net::StreamSocket&) @ 0x00000000314953fa 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x0000000031474ec0 18. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003147f18d 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314a4c99 20. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000314a7804 21. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 22. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 24. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:36:37.019494 [ 4107 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 1.43 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b684b1 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:184: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x0000000023caff0f 12. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x0000000023cb0455 13. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x00000000314982fa 14. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x00000000314982ae 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, Poco::Net::StreamSocket&) @ 0x000000003149559e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], Poco::Net::StreamSocket&, 0>(std::allocator const&, Poco::Net::StreamSocket&) @ 0x00000000314953fa 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x0000000031474ec0 18. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003147f18d 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314a4c99 20. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000314a7804 21. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 22. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 24. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:36:37.030783 [ 4171 ] {681ff35d-3583-468a-b301-a66bd0b37371} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1]. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51570) (comment: 01880_remote_ipv6.sql) (query 15, line 21) (in query: SELECT * FROM remote('[::1][::1]') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0175 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:37.040221 [ 4171 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0175 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:37.123494 [ 4171 ] {350f1587-b276-4b23-836c-eec157d0db7a} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51570) (comment: 01880_remote_ipv6.sql) (query 16, line 22) (in query: SELECT * FROM remote('[::1][::1') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0175 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:37.133506 [ 4171 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0175 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:37.234846 [ 4171 ] {633604eb-9622-4827-9e4c-35a74a83750d} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51570) (comment: 01880_remote_ipv6.sql) (query 17, line 23) (in query: SELECT * FROM remote('[::1]::1]') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0295 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:37.259519 [ 4171 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000017cc4acf 5. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000284f0295 6. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x000000002d433cdf 7. ./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&&) @ 0x000000002d444049 8. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000002d43bb8f 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>, std::allocator>>>&, DB::ClusterConnectionParameters&, std::allocator, 0>(std::allocator, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c1899cf 10. std::shared_ptr std::allocate_shared[abi:ne190107], DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&, 0>(std::allocator const&, DB::Settings const&, std::vector>, std::allocator>>>&, DB::ClusterConnectionParameters&) @ 0x000000001c189826 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002848f6d1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:37.444610 [ 5112 ] {0698c0af-35ab-40bd-b13f-6157b2a956c0} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.44 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 1.91 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51690) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_5.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b684b1 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:184: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x0000000023caff0f 12. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x0000000023cb0455 13. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x00000000314982fa 14. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x00000000314982ae 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, Poco::Net::StreamSocket&) @ 0x000000003149559e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], Poco::Net::StreamSocket&, 0>(std::allocator const&, Poco::Net::StreamSocket&) @ 0x00000000314953fa 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x0000000031474ec0 18. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003147f18d 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314a4c99 20. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000314a7804 21. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 22. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 24. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:36:37.462052 [ 5112 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.44 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 1.91 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b684b1 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:184: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x0000000023caff0f 12. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x0000000023cb0455 13. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x00000000314982fa 14. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x00000000314982ae 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, Poco::Net::StreamSocket&) @ 0x000000003149559e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], Poco::Net::StreamSocket&, 0>(std::allocator const&, Poco::Net::StreamSocket&) @ 0x00000000314953fa 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x0000000031474ec0 18. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003147f18d 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314a4c99 20. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000314a7804 21. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 22. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 24. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:36:37.924176 [ 5163 ] {8d4ee707-bf75-4132-b05f-9b30559dce28} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.44 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 2.38 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51724) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_5.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b684b1 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:184: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x0000000023caff0f 12. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x0000000023cb0455 13. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x00000000314982fa 14. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x00000000314982ae 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, Poco::Net::StreamSocket&) @ 0x000000003149559e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], Poco::Net::StreamSocket&, 0>(std::allocator const&, Poco::Net::StreamSocket&) @ 0x00000000314953fa 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x0000000031474ec0 18. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003147f18d 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314a4c99 20. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000314a7804 21. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 22. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 24. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:36:38.010851 [ 5163 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 2.44 MiB (attempt to allocate chunk of 1.00 MiB bytes), maximum: 2.38 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b684b1 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:184: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x0000000023caff0f 12. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x0000000023cb0455 13. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x00000000314982fa 14. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x00000000314982ae 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, Poco::Net::StreamSocket&) @ 0x000000003149559e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], Poco::Net::StreamSocket&, 0>(std::allocator const&, Poco::Net::StreamSocket&) @ 0x00000000314953fa 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x0000000031474ec0 18. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003147f18d 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000314a4c99 20. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000314a7804 21. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 22. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 24. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:36:38.530360 [ 5163 ] {4c8aa232-ba49-4e54-b326-673e2d101918} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51742) (comment: 02833_window_func_range_offset.sql) (query 1, line 1) (in query: -- invalid start offset with RANGE SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN 0.0 PRECEDING AND UNBOUNDED FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e235e4f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x000000002e2357e2 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc43ae0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cd52 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:36:38.550499 [ 5163 ] {} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e235e4f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x000000002e2357e2 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc43ae0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cd52 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:36:38.640176 [ 5163 ] {8e6da5bc-c29c-405d-badd-2c17efbce81e} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51742) (comment: 02833_window_func_range_offset.sql) (query 2, line 3) (in query: SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN nan PRECEDING AND UNBOUNDED FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e235e4f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x000000002e2357e2 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc43ae0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cd52 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:36:38.650338 [ 5163 ] {} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e235e4f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x000000002e2357e2 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc43ae0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cd52 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:36:38.673923 [ 4107 ] {f18e1d5c-621d-4aac-a355-7ba8458999fe} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 3.46 MiB (attempt to allocate chunk of 1.02 MiB bytes), maximum: 2.86 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51750) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_5.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002c3e7882 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002c3e6425 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002c3e5997 11. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002c3e5512 12. ./build_docker/./src/Client/HedgedConnections.cpp:410: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x00000000314d11d9 13. ./build_docker/./src/Client/HedgedConnections.cpp:389: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x00000000314cf2e7 14. ./build_docker/./src/Client/HedgedConnections.cpp:363: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x00000000314d0703 15. ./build_docker/./src/Client/HedgedConnections.cpp:345: DB::HedgedConnections::receivePacket() @ 0x00000000314d0432 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:509: DB::RemoteQueryExecutor::read() @ 0x000000002c3b5fe3 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:485: DB::RemoteQueryExecutor::readBlock() @ 0x000000002c3b5c7c 18. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:100: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000030846e8d 19. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:160: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000030848be7 20. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000028491e78 21. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284914c0 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 23. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 2025.06.13 15:36:38.709227 [ 4107 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 3.46 MiB (attempt to allocate chunk of 1.02 MiB bytes), maximum: 2.86 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002c3e7882 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002c3e6425 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002c3e5997 11. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002c3e5512 12. ./build_docker/./src/Client/HedgedConnections.cpp:410: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x00000000314d11d9 13. ./build_docker/./src/Client/HedgedConnections.cpp:389: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x00000000314cf2e7 14. ./build_docker/./src/Client/HedgedConnections.cpp:363: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x00000000314d0703 15. ./build_docker/./src/Client/HedgedConnections.cpp:345: DB::HedgedConnections::receivePacket() @ 0x00000000314d0432 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:509: DB::RemoteQueryExecutor::read() @ 0x000000002c3b5fe3 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:485: DB::RemoteQueryExecutor::readBlock() @ 0x000000002c3b5c7c 18. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:100: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000030846e8d 19. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:160: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000030848be7 20. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000028491e78 21. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284914c0 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 23. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 2025.06.13 15:36:38.734755 [ 4969 ] {6d89dc93-f073-4c5a-880b-4f2ba77041d3} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_11jn31ss.quorum1 (a8279faa-ad54-440e-803d-5674ed97eda3)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36668) (comment: 00732_quorum_insert_select_with_old_data_and_without_quorum_zookeeper_long.sql) (query 6, line 13) (in query: INSERT INTO quorum1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:36:38.768636 [ 4969 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_11jn31ss.quorum1 (a8279faa-ad54-440e-803d-5674ed97eda3)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:36:38.798036 [ 3829 ] {f34e83cf-2420-4486-ac29-ac0b0f8c8329} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57672). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:36:38.813582 [ 5163 ] {219eaa54-1bab-48f4-910b-278b82b7ec88} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51742) (comment: 02833_window_func_range_offset.sql) (query 3, line 4) (in query: -- invalid end offset with RANGE SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN UNBOUNDED PRECEDING AND 0.0 FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e235e4f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x000000002e2358a4 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc43ae0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cd52 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:36:38.822359 [ 3829 ] {f34e83cf-2420-4486-ac29-ac0b0f8c8329} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57672). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:57672) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: DESC TABLE test_5.numbers_100k), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:36:38.824482 [ 5163 ] {} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e235e4f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x000000002e2358a4 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc43ae0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cd52 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:36:38.831626 [ 3829 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57672). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:36:38.988111 [ 5163 ] {c556df7b-945d-4f1d-b3df-aa1da54a6dc7} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51742) (comment: 02833_window_func_range_offset.sql) (query 4, line 6) (in query: SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN UNBOUNDED PRECEDING AND nan FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e235e4f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x000000002e2358a4 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc43ae0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cd52 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:36:38.996221 [ 5163 ] {} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x000000002e235e4f 5. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x000000002e2358a4 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2564: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc43ae0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3290: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cd52 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:36:39.063202 [ 3869 ] {aef27c7d-63c8-44bb-bc3b-875d37b0c6f1} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_11jn31ss.quorum1 (a8279faa-ad54-440e-803d-5674ed97eda3)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34984) (comment: 00732_quorum_insert_select_with_old_data_and_without_quorum_zookeeper_long.sql) (in query: DROP DATABASE IF EXISTS test_11jn31ss SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:39.175237 [ 3869 ] {aef27c7d-63c8-44bb-bc3b-875d37b0c6f1} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_11jn31ss.quorum1 (a8279faa-ad54-440e-803d-5674ed97eda3)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:36:39.634500 [ 4107 ] {ddae9dbe-5c9d-4132-9672-dc96b0eb177d} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 3.46 MiB (attempt to allocate chunk of 1.02 MiB bytes), maximum: 3.34 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51796) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_5.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002c3e7882 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002c3e6425 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002c3e5997 11. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002c3e5512 12. ./build_docker/./src/Client/HedgedConnections.cpp:410: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x00000000314d11d9 13. ./build_docker/./src/Client/HedgedConnections.cpp:389: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x00000000314cf2e7 14. ./build_docker/./src/Client/HedgedConnections.cpp:363: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x00000000314d0703 15. ./build_docker/./src/Client/HedgedConnections.cpp:345: DB::HedgedConnections::receivePacket() @ 0x00000000314d0432 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:509: DB::RemoteQueryExecutor::read() @ 0x000000002c3b5fe3 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:485: DB::RemoteQueryExecutor::readBlock() @ 0x000000002c3b5c7c 18. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:100: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000030846e8d 19. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:160: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000030848be7 20. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000028491e78 21. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284914c0 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 23. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 2025.06.13 15:36:39.636860 [ 5110 ] {e23898c2-b8e6-4204-adf6-ae9c09d3b3c8} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57676). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:36:39.644703 [ 5110 ] {e23898c2-b8e6-4204-adf6-ae9c09d3b3c8} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57676). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:57676) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: DESC TABLE test_5.numbers_100k), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:36:39.661320 [ 4107 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 3.46 MiB (attempt to allocate chunk of 1.02 MiB bytes), maximum: 3.34 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002c3e7882 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002c3e6425 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002c3e5997 11. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002c3e5512 12. ./build_docker/./src/Client/HedgedConnections.cpp:410: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x00000000314d11d9 13. ./build_docker/./src/Client/HedgedConnections.cpp:389: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x00000000314cf2e7 14. ./build_docker/./src/Client/HedgedConnections.cpp:363: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x00000000314d0703 15. ./build_docker/./src/Client/HedgedConnections.cpp:345: DB::HedgedConnections::receivePacket() @ 0x00000000314d0432 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:509: DB::RemoteQueryExecutor::read() @ 0x000000002c3b5fe3 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:485: DB::RemoteQueryExecutor::readBlock() @ 0x000000002c3b5c7c 18. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:100: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000030846e8d 19. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:160: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000030848be7 20. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000028491e78 21. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284914c0 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 23. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 2025.06.13 15:36:39.669865 [ 5110 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57676). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:36:40.404812 [ 5005 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:36:40.456415 [ 4172 ] {5172b15b-7188-4ffc-8a23-52e0b8ea5b65} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.72 MiB (attempt to allocate chunk of 1.26 MiB bytes), maximum: 3.81 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51898) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_5.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002c3e7882 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002c3e6425 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002c3e5997 11. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002c3e5512 12. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::resumeConnectionEstablisher(int, DB::Connection*&) @ 0x00000000314dc252 13. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:211: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314da9da 14. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314c8c77 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3cac25 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3bfc07 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3b27e1 18. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3ea61f 19. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 20. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:36:40.462371 [ 5005 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:36:40.494562 [ 4172 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.72 MiB (attempt to allocate chunk of 1.26 MiB bytes), maximum: 3.81 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002c3e7882 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002c3e6425 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002c3e5997 11. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002c3e5512 12. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::resumeConnectionEstablisher(int, DB::Connection*&) @ 0x00000000314dc252 13. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:211: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314da9da 14. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314c8c77 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3cac25 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3bfc07 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3b27e1 18. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3ea61f 19. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 20. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:36:40.748979 [ 5110 ] {cca37838-16d0-4ac2-9263-4f964e0eef6a} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 3.89 MiB (attempt to allocate chunk of 1.37 MiB bytes), maximum: 3.81 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:57678) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(`__table1`.`number`, 5) AS `k`, max(toString(`__table1`.`number`)) AS `max(toString(number))` FROM `test_5`.`numbers_100k` AS `__table1` GROUP BY intDiv(`__table1`.`number`, 5) ORDER BY intDiv(`__table1`.`number`, 5) ASC LIMIT _CAST(1, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. DB::Arena::MemoryChunk::MemoryChunk(unsigned long) @ 0x0000000018f0acf1 10. DB::Arena::addMemoryChunk(unsigned long) @ 0x0000000018f0aa88 11. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x0000000018f0aa28 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1148: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000002d888925 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d88687d 14. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002d744416 15. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d6b47a9 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6bc532 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d8bba4 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d85ecd 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:36:40.849415 [ 5110 ] {cca37838-16d0-4ac2-9263-4f964e0eef6a} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57678). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316ba300 7. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x00000000316a4b63 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:36:40.890784 [ 5110 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 3.89 MiB (attempt to allocate chunk of 1.37 MiB bytes), maximum: 3.81 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. DB::Arena::MemoryChunk::MemoryChunk(unsigned long) @ 0x0000000018f0acf1 10. DB::Arena::addMemoryChunk(unsigned long) @ 0x0000000018f0aa88 11. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x0000000018f0aa28 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1148: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000002d888925 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d88687d 14. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002d744416 15. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d6b47a9 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6bc532 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d8bba4 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d85ecd 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:36:40.995750 [ 3931 ] {fdf0b961-6995-4da2-9b47-f0c7c413391e} executeQuery: Code: 60. DB::Exception: Table test_15.nbagames does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51960) (comment: 01825_type_json_nbagames.sh) (query 1, line 1) (in query: INSERT INTO nbagames FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:36:41.045836 [ 3931 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.nbagames does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:36:41.098200 [ 3821 ] {5bf74d2f-1fb5-4151-b154-046ef54c5d45} executeQuery: Code: 36. DB::Exception: Log name 'no_such_log_and_never_will_be' does not exist. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51958) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Interpreters/SystemLog.cpp:423: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x000000002e002dff 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x000000002e2ee89e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:36:41.133504 [ 3821 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Interpreters/SystemLog.cpp:423: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x000000002e002dff 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x000000002e2ee89e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:36:41.451931 [ 5112 ] {26d6af8c-7f0a-4c79-957b-1d88f3da074f} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.72 MiB (attempt to allocate chunk of 1.26 MiB bytes), maximum: 4.29 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51990) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_5.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002c3e7882 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002c3e6425 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002c3e5997 11. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002c3e5512 12. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::resumeConnectionEstablisher(int, DB::Connection*&) @ 0x00000000314dc252 13. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:211: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314da9da 14. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314c8c77 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3cac25 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3bfc07 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3b27e1 18. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3ea61f 19. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 20. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:36:41.479709 [ 5112 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 4.72 MiB (attempt to allocate chunk of 1.26 MiB bytes), maximum: 4.29 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002c3e7882 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002c3e6425 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002c3e5997 11. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002c3e5512 12. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::resumeConnectionEstablisher(int, DB::Connection*&) @ 0x00000000314dc252 13. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:211: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x00000000314da9da 14. ./build_docker/./src/Client/HedgedConnections.cpp:67: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x00000000314c8c77 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002c3cac25 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002c3bfc07 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3b27e1 18. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3ea61f 19. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 20. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:36:41.593959 [ 3821 ] {9c1db1d3-5fb2-40b4-959f-6e681defd779} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames' in scope SELECT count() FROM nbagames WHERE NOT ignore(*). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52016) (comment: 01825_type_json_nbagames.sh) (query 1, line 1) (in query: SELECT count() FROM nbagames WHERE NOT ignore(*)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:36:41.618344 [ 3821 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames' in scope SELECT count() FROM nbagames WHERE NOT ignore(*). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:36:41.618958 [ 3869 ] {65db0f4a-4b35-48bf-9658-c3ca31f162ac} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.06 MiB (attempt to allocate chunk of 1.17 MiB bytes), maximum: 4.29 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:57688) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(`__table1`.`number`, 5) AS `k`, max(toString(`__table1`.`number`)) AS `max(toString(number))` FROM `test_5`.`numbers_100k` AS `__table1` GROUP BY intDiv(`__table1`.`number`, 5) ORDER BY intDiv(`__table1`.`number`, 5) ASC LIMIT _CAST(1, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. DB::Arena::MemoryChunk::MemoryChunk(unsigned long) @ 0x0000000018f0acf1 10. DB::Arena::addMemoryChunk(unsigned long) @ 0x0000000018f0aa88 11. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x0000000018f0aa28 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1148: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000002d888925 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d88687d 14. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002d744416 15. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d6b47a9 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6bc532 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d8bba4 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d85ecd 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:36:41.626724 [ 3869 ] {65db0f4a-4b35-48bf-9658-c3ca31f162ac} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57688). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316ba300 7. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x00000000316a4b63 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:36:41.630176 [ 3869 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 5.06 MiB (attempt to allocate chunk of 1.17 MiB bytes), maximum: 4.29 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. DB::Arena::MemoryChunk::MemoryChunk(unsigned long) @ 0x0000000018f0acf1 10. DB::Arena::addMemoryChunk(unsigned long) @ 0x0000000018f0aa88 11. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x0000000018f0aa28 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1148: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000002d888925 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d88687d 14. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x000000002d744416 15. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000002d6b47a9 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6bc532 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d8bba4 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d85ecd 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:36:42.288861 [ 5978 ] {c7583fba-47cf-4a53-96ed-f61e2308901c} executeQuery: Code: 60. DB::Exception: Table test_15.nbagames does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52106) (comment: 01825_type_json_nbagames.sh) (query 1, line 1) (in query: DESC nbagames SETTINGS describe_extend_object_types = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:182: DB::InterpreterDescribeQuery::fillColumnsFromTable(DB::ASTTableExpression const&) @ 0x000000002e331c34 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:104: DB::InterpreterDescribeQuery::execute() @ 0x000000002e32f5d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:36:42.303490 [ 3821 ] {55aa130e-d808-41f6-b69e-6f0676d00545} 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.20286.altinityantalya (altinity build)) (from [::1]:52070) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 2) (in query: SELECT intDiv(number, 5) AS k, max(toString(number)) FROM remote('127.0.0.{2,3}', test_5.numbers_100k) GROUP BY k ORDER BY k LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:36:42.310168 [ 5978 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.nbagames does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:182: DB::InterpreterDescribeQuery::fillColumnsFromTable(DB::ASTTableExpression const&) @ 0x000000002e331c34 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:104: DB::InterpreterDescribeQuery::execute() @ 0x000000002e32f5d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:36:42.336768 [ 3821 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:36:42.756701 [ 5110 ] {4f00dc06-93a5-4eb9-8f30-53c0831a72a1} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames' in scope SELECT teams.name AS name, sum(teams.won) AS wins FROM nbagames ARRAY JOIN data.teams AS teams GROUP BY name ORDER BY wins DESC LIMIT 5. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52140) (comment: 01825_type_json_nbagames.sh) (query 1, line 1) (in query: SELECT teams.name AS name, sum(teams.won) AS wins FROM nbagames ARRAY JOIN data.teams AS teams GROUP BY name ORDER BY wins DESC LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:36:42.783587 [ 5110 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames' in scope SELECT teams.name AS name, sum(teams.won) AS wins FROM nbagames ARRAY JOIN data.teams AS teams GROUP BY name ORDER BY wins DESC LIMIT 5. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:36:43.172972 [ 5978 ] {889f86ca-3e74-409d-80ca-3427d49a6182} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (in query: /* ddl_entry=query-0000000007 */ TRUNCATE TABLE test_5.numbers_100k), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:36:43.314282 [ 5978 ] {889f86ca-3e74-409d-80ca-3427d49a6182} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52146) (comment: 00133_long_shard_memory_tracker_and_exception_safety.sh) (query 1, line 1) (in query: DROP TABLE numbers_100k;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:36:43.325509 [ 5978 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:36:43.440204 [ 4171 ] {37af5db4-23f1-4873-8ad9-ad33fab9c88c} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames' in scope SELECT arrayJoin(arrayJoin(data.teams.players)) AS players FROM nbagames. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60200) (comment: 01825_type_json_nbagames.sh) (query 1, line 1) (in query: SELECT player, sum(triple_double) AS triple_doubles FROM ( SELECT tupleElement(players, 'player') AS player, ((tupleElement(players, 'pts') >= 10) + (tupleElement(players, 'ast') >= 10) + (tupleElement(players, 'blk') >= 10) + (tupleElement(players, 'stl') >= 10) + (tupleElement(players, 'trb') >= 10)) >= 3 AS triple_double FROM ( SELECT arrayJoin(arrayJoin(data.teams.players)) as players from nbagames ) ) GROUP BY player ORDER BY triple_doubles DESC, player LIMIT 5), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:43.458162 [ 4171 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames' in scope SELECT arrayJoin(arrayJoin(data.teams.players)) AS players FROM nbagames. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:36:43.823593 [ 5110 ] {524dbcf1-423a-423a-9dc3-611fe4bf2585} 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.20286.altinityantalya (altinity build)) (from [::1]:60230) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionArrayJaccardIndex::getReturnTypeImpl(std::vector> const&) const @ 0x0000000022ea8a17 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:36:43.836236 [ 5110 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionArrayJaccardIndex::getReturnTypeImpl(std::vector> const&) const @ 0x0000000022ea8a17 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:36:44.130685 [ 5110 ] {2478924d-7abe-4c35-aef4-16e988511b8b} 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.20286.altinityantalya (altinity build)) (from [::1]:60230) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::FunctionArrayJaccardIndex::vectorWithEmptyIntersect(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x0000000022ea8fc7 6. DB::FunctionArrayJaccardIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000022ea6be5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:36:44.135014 [ 5110 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::FunctionArrayJaccardIndex::vectorWithEmptyIntersect(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x0000000022ea8fc7 6. DB::FunctionArrayJaccardIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000022ea6be5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:36:44.276277 [ 5110 ] {9537ee44-2ce1-42ce-8c2d-2d2f1302342f} 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.20286.altinityantalya (altinity build)) (from [::1]:60230) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/DataTypes/getMostSubtype.cpp:53: DB::getMostSubtype(std::vector, std::allocator>> const&, bool, bool)::$_0::operator()(String const&) const @ 0x000000002c51fce2 5. ./build_docker/./src/DataTypes/getMostSubtype.cpp:232: DB::getMostSubtype(std::vector, std::allocator>> const&, bool, bool) @ 0x000000002c51f0ce 6. DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000022e05176 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. DB::FunctionArrayJaccardIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000022ea6000 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:36:44.300665 [ 5110 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/DataTypes/getMostSubtype.cpp:53: DB::getMostSubtype(std::vector, std::allocator>> const&, bool, bool)::$_0::operator()(String const&) const @ 0x000000002c51fce2 5. ./build_docker/./src/DataTypes/getMostSubtype.cpp:232: DB::getMostSubtype(std::vector, std::allocator>> const&, bool, bool) @ 0x000000002c51f0ce 6. DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000022e05176 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. DB::FunctionArrayJaccardIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000022ea6000 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:36:44.480278 [ 4171 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:36:44.492560 [ 4171 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:36:45.791780 [ 5163 ] {f3832a4d-e404-4433-a6fd-3d780a4e306c} executeQuery: Code: 44. DB::Exception: Cannot drop column `x`, because column `y` depends on it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60236) (comment: 01387_clear_column_default_depends.sql) (query 7, line 10) (in query: ALTER TABLE test DROP COLUMN x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1606: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cab0d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:36:45.824081 [ 5163 ] {} TCPHandler: Code: 44. DB::Exception: Cannot drop column `x`, because column `y` depends on it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1606: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cab0d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:36:45.988140 [ 6234 ] {488ec8fe-8664-416f-9efa-650116bd7e32} executeQuery: Code: 60. DB::Exception: Table test_15.nbagames_from_string does not exist. Maybe you meant test_15.nbagames_string?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60370) (comment: 01825_type_json_nbagames.sh) (query 1, line 1) (in query: INSERT INTO nbagames_from_string SELECT data FROM nbagames_string), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:36:46.028807 [ 6234 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.nbagames_from_string does not exist. Maybe you meant test_15.nbagames_string?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:36:46.331230 [ 4108 ] {40b42512-2464-4aab-80a9-6ed472017569} executeQuery: Code: 507. DB::Exception: No sharding key. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52126) (comment: 01071_force_optimize_skip_unused_shards.sql) (query 14, line 19) (in query: select * from dist_01071;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1560: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003038b9f7 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030389607 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda0ed6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:46.343234 [ 4108 ] {} TCPHandler: Code: 507. DB::Exception: No sharding key. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1560: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003038b9f7 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030389607 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda0ed6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:46.682373 [ 6155 ] {1c13aa7e-d700-4f0a-b04d-2dfa99cd2451} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames_from_string' in scope (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM nbagames_from_string). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60416) (comment: 01825_type_json_nbagames.sh) (query 1, line 1) (in query: SELECT (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM nbagames_from_string) = (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM nbagames)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:36:46.690778 [ 6155 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'nbagames_from_string' in scope (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM nbagames_from_string). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:36:46.935108 [ 4098 ] {3baf608d-7b46-4815-84f7-bfc072914add} executeQuery: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49176) (comment: 02946_parallel_replicas_force_primary_key.sql) (query 16, line 38) (in query: SELECT `__table1`.`k` AS `k`, count() AS `count()` FROM `test_1`.`t1` AS `__table1` GROUP BY `__table1`.`k` ORDER BY `__table1`.`k` ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:36:46.936041 [ 3895 ] {f94d395c-70bf-4faf-90ce-5745ff49c580} executeQuery: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:41066) (comment: 02946_parallel_replicas_force_primary_key.sql) (query 16, line 38) (in query: SELECT `__table1`.`k` AS `k`, count() AS `count()` FROM `test_1`.`t1` AS `__table1` GROUP BY `__table1`.`k` ORDER BY `__table1`.`k` ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:36:46.937624 [ 5997 ] {e08ef828-d617-4661-ac25-ad75ce17537f} executeQuery: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43630) (comment: 02946_parallel_replicas_force_primary_key.sql) (query 16, line 38) (in query: SELECT `__table1`.`k` AS `k`, count() AS `count()` FROM `test_1`.`t1` AS `__table1` GROUP BY `__table1`.`k` ORDER BY `__table1`.`k` ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:36:46.939197 [ 4098 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:36:46.944712 [ 3895 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:36:46.945506 [ 5997 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:36:46.969822 [ 2862 ] {3a7d0ae3-cc57-4bbf-aec9-af8d3f927903} executeQuery: Code: 277. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 : While executing Remote. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51610) (comment: 02946_parallel_replicas_force_primary_key.sql) (query 16, line 38) (in query: -- parallel replicas, primary key is NOT used SELECT k, count() FROM t1 GROUP BY k ORDER BY k SETTINGS force_primary_key = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:36:46.983207 [ 2862 ] {} TCPHandler: Code: 277. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 : While executing Remote. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:36:47.453654 [ 5163 ] {927fd5fb-c437-4345-9990-287d3e7027e9} executeQuery: Code: 44. DB::Exception: Cannot drop column `x`, because column `y` depends on it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60236) (comment: 01387_clear_column_default_depends.sql) (query 15, line 19) (in query: ALTER TABLE test DROP COLUMN x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1606: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cab0d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:36:47.458986 [ 5163 ] {} TCPHandler: Code: 44. DB::Exception: Cannot drop column `x`, because column `y` depends on it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1606: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cab0d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:36:47.695882 [ 6236 ] {0244b061-ddaf-47b2-b121-2d6eed53d5e7} executeQuery: Code: 16. DB::Exception: There is no column with name `alias` in table test_ps7bq3we.full_duplicates (9ff4175c-b114-4df4-8e56-9d60f6e311b0). There are columns: pk, sk, val, partition_key, mat. (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60384) (comment: 01581_deduplicate_by_columns_local.sql) (query 7, line 27) (in query: -- ERROR cases OPTIMIZE TABLE full_duplicates DEDUPLICATE BY pk, sk, val, mat, alias;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x000000002d60b76f 5. ./build_docker/./src/Storages/StorageSnapshot.cpp:283: DB::StorageSnapshot::check(std::vector> const&) const @ 0x00000000307d8246 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:58: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325b0a 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:36:47.711902 [ 6236 ] {} TCPHandler: Code: 16. DB::Exception: There is no column with name `alias` in table test_ps7bq3we.full_duplicates (9ff4175c-b114-4df4-8e56-9d60f6e311b0). There are columns: pk, sk, val, partition_key, mat. (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x000000002d60b76f 5. ./build_docker/./src/Storages/StorageSnapshot.cpp:283: DB::StorageSnapshot::check(std::vector> const&) const @ 0x00000000307d8246 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:58: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325b0a 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:36:47.807905 [ 6236 ] {ef9abd89-0f8c-452b-b187-fe96e578f4a9} executeQuery: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'pk' is missing. Expanded DEDUPLICATE BY columns expression: ['sk', 'val']. (THERE_IS_NO_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60384) (comment: 01581_deduplicate_by_columns_local.sql) (query 8, line 29) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY sk, val;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002b79914f 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e3262c5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:36:47.820604 [ 6236 ] {} TCPHandler: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'pk' is missing. Expanded DEDUPLICATE BY columns expression: ['sk', 'val']. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002b79914f 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e3262c5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:36:48.056577 [ 6236 ] {25522515-110a-46a7-8b19-1cb20bc3ba25} executeQuery: Code: 51. DB::Exception: Empty list of columns queried. There are columns: pk, sk, val, partition_key, mat. (EMPTY_LIST_OF_COLUMNS_QUERIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60384) (comment: 01581_deduplicate_by_columns_local.sql) (query 9, line 30) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY * EXCEPT(pk, sk, val, mat, alias, partition_key);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Storages/StorageSnapshot.cpp:267: DB::StorageSnapshot::check(std::vector> const&) const @ 0x00000000307d8367 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:58: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325b0a 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:36:48.063908 [ 6236 ] {} TCPHandler: Code: 51. DB::Exception: Empty list of columns queried. There are columns: pk, sk, val, partition_key, mat. (EMPTY_LIST_OF_COLUMNS_QUERIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Storages/StorageSnapshot.cpp:267: DB::StorageSnapshot::check(std::vector> const&) const @ 0x00000000307d8367 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:58: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325b0a 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:36:48.159754 [ 6236 ] {15d60393-3c09-4706-aa16-1c88ba585b5b} executeQuery: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'pk' is missing. Expanded DEDUPLICATE BY columns expression: ['sk', 'val', 'partition_key']. (THERE_IS_NO_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60384) (comment: 01581_deduplicate_by_columns_local.sql) (query 10, line 31) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY * EXCEPT(pk);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002b79914f 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e3262c5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:36:48.170490 [ 6236 ] {} TCPHandler: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'pk' is missing. Expanded DEDUPLICATE BY columns expression: ['sk', 'val', 'partition_key']. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002b79914f 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e3262c5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:36:48.255720 [ 6236 ] {796f91c8-7533-4acb-8268-d755f890b253} executeQuery: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'sk' is missing. Expanded DEDUPLICATE BY columns expression: ['pk', 'val', 'partition_key']. (THERE_IS_NO_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60384) (comment: 01581_deduplicate_by_columns_local.sql) (query 11, line 32) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY * EXCEPT(sk);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002b79914f 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e3262c5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:36:48.282227 [ 6236 ] {} TCPHandler: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'sk' is missing. Expanded DEDUPLICATE BY columns expression: ['pk', 'val', 'partition_key']. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002b79914f 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e3262c5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:36:48.415710 [ 6236 ] {ccf784d4-a62b-48c1-84a4-3e00bbda7814} executeQuery: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'partition_key' is missing. Expanded DEDUPLICATE BY columns expression: ['pk', 'sk', 'val']. (THERE_IS_NO_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60384) (comment: 01581_deduplicate_by_columns_local.sql) (query 12, line 33) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY * EXCEPT(partition_key);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002b79914f 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e3262c5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:36:48.433115 [ 6236 ] {} TCPHandler: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'partition_key' is missing. Expanded DEDUPLICATE BY columns expression: ['pk', 'sk', 'val']. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002b79914f 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e3262c5 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 8. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:36:49.290617 [ 4108 ] {e7db3261-b2ba-461d-9dc3-d91391e73d3b} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52126) (comment: 01071_force_optimize_skip_unused_shards.sql) (query 20, line 26) (in query: select * from dist_01071;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003038b83b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030389607 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda0ed6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:49.308708 [ 4108 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003038b83b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030389607 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda0ed6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:49.556860 [ 4108 ] {aa6bc2d5-68d2-4aa3-98d2-230bfb68d666} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52126) (comment: 01071_force_optimize_skip_unused_shards.sql) (query 22, line 28) (in query: select * from dist_01071;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003038b83b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030389607 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda0ed6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:49.624904 [ 4108 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003038b83b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030389607 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda0ed6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:49.638814 [ 5163 ] {212d98c3-5bc0-4da1-af9b-16e89bbcdbae} executeQuery: Code: 44. DB::Exception: Cannot drop column `x`, because column `y` depends on it. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60236) (comment: 01387_clear_column_default_depends.sql) (query 23, line 28) (in query: ALTER TABLE test DROP COLUMN x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1606: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cab0d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:36:49.709844 [ 5163 ] {} TCPHandler: Code: 44. DB::Exception: Cannot drop column `x`, because column `y` depends on it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1606: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cab0d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:36:49.900186 [ 5112 ] {f555328c-a03a-479b-a8ef-5b10d5d5f536} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60580) (comment: 01178_int_field_to_decimal.sql) (query 1, line 1) (in query: select d from values('d Decimal(8, 8)', 0, 1) where d not in (-1, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000002e25dfd4 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e254921 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e258986 9. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284db786 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:49.911725 [ 5112 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000002e25dfd4 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e254921 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e258986 9. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284db786 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:50.000592 [ 3931 ] {0888cad2-c015-401e-ba14-271a1603a36d} executeQuery: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60558) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99bb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:36:50.007307 [ 5112 ] {2ecc0d50-4a85-4fbe-b5cf-5cbcb9ecff92} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60580) (comment: 01178_int_field_to_decimal.sql) (query 2, line 2) (in query: select d from values('d Decimal(8, 8)', 0, 2) where d not in (1, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000002e25dfd4 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e254921 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e258986 9. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284db786 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:50.012340 [ 5112 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000002e25dfd4 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e254921 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e258986 9. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284db786 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 11. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:36:50.047033 [ 3931 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99bb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:36:50.179485 [ 3931 ] {1f95fda3-d151-4acc-a90b-1d19ca3fda24} executeQuery: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60558) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99bb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:36:50.186985 [ 3931 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99bb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:36:50.236066 [ 5112 ] {8165357e-ec6c-4dbf-812d-93289c89f846} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60580) (comment: 01178_int_field_to_decimal.sql) (query 3, line 3) (in query: select d from values('d Decimal(9, 8)', 0, 3) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000002e25e09f 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e254921 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d150b9c 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x000000002d14d7bd 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000002d161f75 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000002d161667 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000002d161514 14. ./build_docker/./src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6b4fd 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:36:50.253474 [ 3931 ] {67853428-e66d-4ec6-86ef-c45b170bdca4} executeQuery: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60558) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99bb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:36:50.268546 [ 3931 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99bb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:36:50.320539 [ 5112 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000002e25e09f 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e254921 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d150b9c 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x000000002d14d7bd 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000002d161f75 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000002d161667 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000002d161514 14. ./build_docker/./src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6b4fd 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:36:50.442224 [ 5112 ] {592589d1-8bbe-4c70-a900-05107bda115d} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60580) (comment: 01178_int_field_to_decimal.sql) (query 4, line 4) (in query: select d from values('d Decimal(9, 8)', 0, 4) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000002e25dfd4 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e254921 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d150b9c 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x000000002d14d7bd 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000002d161f75 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000002d161667 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000002d161514 14. ./build_docker/./src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6b4fd 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:36:50.452146 [ 5112 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000002e25dfd4 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e254921 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d150b9c 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x000000002d14d7bd 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000002d161f75 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000002d161667 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000002d161514 14. ./build_docker/./src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6b4fd 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:36:50.727494 [ 5112 ] {085fd37b-0c18-40b6-930b-39e93ea79b00} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60580) (comment: 01178_int_field_to_decimal.sql) (query 5, line 5) (in query: select d from values('d Decimal(18, 8)', 0, 5) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000002e25eeff 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:255: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e2549fd 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d150b9c 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x000000002d14d7bd 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000002d161f75 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000002d161667 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000002d161514 14. ./build_docker/./src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6b4fd 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:36:50.736568 [ 5112 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000002e25eeff 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:255: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e2549fd 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d150b9c 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x000000002d14d7bd 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000002d161f75 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000002d161667 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000002d161514 14. ./build_docker/./src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6b4fd 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:36:50.879457 [ 5112 ] {74593d2c-3a7f-4975-915b-e90506fb0632} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60580) (comment: 01178_int_field_to_decimal.sql) (query 6, line 6) (in query: select d from values('d Decimal(18, 8)', 0, 6) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000002e25ee34 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:255: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e2549fd 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d150b9c 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x000000002d14d7bd 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000002d161f75 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000002d161667 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000002d161514 14. ./build_docker/./src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6b4fd 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:36:50.906991 [ 5112 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x000000002e25ee34 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:255: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e2549fd 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d150b9c 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x000000002d14d7bd 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000002d161f75 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000002d161667 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000002d161514 14. ./build_docker/./src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6b4fd 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:36:51.024979 [ 5112 ] {a02c1e98-59b8-41ed-a5ca-64d0ca1959f6} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(26, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60580) (comment: 01178_int_field_to_decimal.sql) (query 7, line 7) (in query: select d from values('d Decimal(26, 8)', 0, 7) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x000000002e25fd92 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:257: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e254a2a 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d150b9c 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x000000002d14d7bd 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000002d161f75 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000002d161667 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000002d161514 14. ./build_docker/./src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6b4fd 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:36:51.035074 [ 5112 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(26, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x000000002e25fd92 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:257: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e254a2a 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d150b9c 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x000000002d14d7bd 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000002d161f75 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000002d161667 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000002d161514 14. ./build_docker/./src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6b4fd 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:36:51.064616 [ 4108 ] {e2c91b12-eb5e-465c-9b39-0ec7dd504cd3} executeQuery: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52126) (comment: 01071_force_optimize_skip_unused_shards.sql) (query 26, line 34) (in query: select * from dist_01071 where key = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1562: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003038ba5a 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030389607 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda0ed6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:51.078386 [ 4108 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1562: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003038ba5a 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030389607 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda0ed6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:51.352735 [ 5112 ] {4cbdfe21-c28d-4d33-b34b-d893d51095f4} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(27, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60580) (comment: 01178_int_field_to_decimal.sql) (query 8, line 8) (in query: select d from values('d Decimal(27, 8)', 0, 8) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x000000002e25fcbf 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:257: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e254a2a 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d150b9c 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x000000002d14d7bd 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000002d161f75 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000002d161667 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000002d161514 14. ./build_docker/./src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6b4fd 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:36:51.368127 [ 5112 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(27, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x000000002e25fcbf 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:257: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e254a2a 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d150b9c 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x000000002d14d7bd 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000002d161f75 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000002d161667 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000002d161514 14. ./build_docker/./src/Planner/Planner.cpp:1485: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6b4fd 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:36:52.192413 [ 4171 ] {29ddb528-462a-461f-9715-eac1aef58fb5} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60760) (comment: 01825_type_json_parallel_insert.sql) (query 2, line 4) (in query: SET allow_experimental_object_type = 1, max_insert_threads = 20, max_threads = 20, min_insert_block_size_rows = 65536;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:36:52.238847 [ 4171 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:36:54.287313 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:36:54.296811 [ 6155 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:36:55.153773 [ 6219 ] {22bd469e-7762-461b-96a4-642acf612e89} executeQuery: Code: 507. DB::Exception: Sharding key modulo(sub_key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:45588) (comment: 01071_force_optimize_skip_unused_shards.sql) (query 34, line 45) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`sub_key` AS `sub_key` FROM `test_qzkecosa`.`dist2_layer_01071` AS `__table1` WHERE `__table1`.`key` = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003038b83b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030389607 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda0ed6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:55.169672 [ 6219 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(sub_key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003038b83b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030389607 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda0ed6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:36:55.272813 [ 4108 ] {821e1454-6cb3-4d54-83e5-9dd580678f96} executeQuery: Code: 507. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Sharding key modulo(sub_key, 2) is not used. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003038b83b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030389607 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda0ed6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 : While executing Remote. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52126) (comment: 01071_force_optimize_skip_unused_shards.sql) (query 34, line 45) (in query: select * from dist2_01071 where key = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:36:55.291831 [ 4108 ] {} TCPHandler: Code: 507. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Sharding key modulo(sub_key, 2) is not used. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003038b83b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030389607 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda0ed6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 : While executing Remote. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:36:59.515952 [ 3110 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x000000002d5f8b30 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000002d5f92c1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:03.396852 [ 6618 ] {351f3494-54b0-4bdd-b3f9-ae06afc16063} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Anti. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34806) (comment: 02785_left_anti_join_bug.sql) (query 8, line 12) (in query: SELECT * FROM (SELECT CAST('104857.5', 'Float32'), corr(NULL, id, id) AS corr_value FROM test_table__fuzz_3 GROUP BY value) AS subquery ANTI LEFT JOIN test_table ON subquery.corr_value = test_table.id format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x0000000031dec10f 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:446: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x0000000031ddce14 6. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x0000000031ddd561 7. ./src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x0000000031deb2b4 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::vector>&, DB::Block const&, unsigned long&, std::allocator, 0>(std::allocator, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3a1eda 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, 0>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3a1cee 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002c395a69 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000032129489 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:03.426190 [ 6618 ] {} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Anti. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x0000000031dec10f 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:446: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x0000000031ddce14 6. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x0000000031ddd561 7. ./src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x0000000031deb2b4 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::vector>&, DB::Block const&, unsigned long&, std::allocator, 0>(std::allocator, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3a1eda 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, 0>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3a1cee 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002c395a69 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000032129489 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:03.873741 [ 3338 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x000000002d5f8b30 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000002d5f92c1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:04.660701 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:04.677444 [ 6155 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:37:05.861256 [ 6618 ] {4bcef51b-0b64-4953-85a3-e17dbae1a0c0} executeQuery: Code: 469. DB::Exception: Constraint `c1` for table test_61ob1deu.t0 (d9a215e7-a9ef-4a0c-9aca-ec570aca8848) is violated at row 1. Expression: (c0 > 5). Column values: c0 = 3. (VIOLATED_CONSTRAINT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40066) (comment: 03262_udf_in_constraint.sh) (query 5, line 6) (in query: INSERT INTO t0(c0) VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5e9077 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031da1148 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:37:05.882726 [ 6618 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c1` for table test_61ob1deu.t0 (d9a215e7-a9ef-4a0c-9aca-ec570aca8848) is violated at row 1. Expression: (c0 > 5). Column values: c0 = 3. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5e9077 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031da1148 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:37:06.248420 [ 6155 ] {54d9d9e6-9f2f-45de-882b-9ec229b2db5d} executeQuery: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (j) using identifier 'j' cannot be resolved from left table expression. In scope SELECT a, b AS j, b AS bb FROM test_tya2n6nf.a INNER JOIN (SELECT b AS j, b AS bb FROM test_tya2n6nf.b) USING (j). (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40082) (comment: 03107_ill_formed_select_in_materialized_view.sql) (query 7, line 12) (in query: CREATE MATERIALIZED VIEW view_4 ( bb UInt64, cnt UInt64) Engine=MergeTree ORDER BY bb POPULATE AS SELECT bb, count() AS cnt FROM (SELECT a, b AS j, b AS bb FROM a INNER JOIN (SELECT b AS j, b AS bb FROM b ) USING (j)) GROUP BY bb;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000002cc5bacf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc56579 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dce0826 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5edc 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2218: DB::InterpreterCreateQuery::fillTableIfNeeded(DB::ASTCreateQuery const&) @ 0x000000002dc83b1a 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1751: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72b9e 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:37:06.286014 [ 6155 ] {} TCPHandler: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (j) using identifier 'j' cannot be resolved from left table expression. In scope SELECT a, b AS j, b AS bb FROM test_tya2n6nf.a INNER JOIN (SELECT b AS j, b AS bb FROM test_tya2n6nf.b) USING (j). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000002cc5bacf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc56579 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dce0826 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5edc 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2218: DB::InterpreterCreateQuery::fillTableIfNeeded(DB::ASTCreateQuery const&) @ 0x000000002dc83b1a 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1751: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72b9e 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:37:07.924996 [ 3727 ] {} test_15.null_00634 (0970b4d7-5e41-49d5-8dc7-613aec0ede2f): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.13 15:37:07.971121 [ 3727 ] {} DatabaseCatalog: Cannot drop table test_15.null_00634 (0970b4d7-5e41-49d5-8dc7-613aec0ede2f). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cafe6a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030caed0f 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cbb267 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d5f99b1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d607d44 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:08.611477 [ 6234 ] {5159f4ea-6b77-4b35-af40-5170016658e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTimeToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40214) (comment: 01942_dateTimeToSnowflake.sql) (query 3, line 4) (in query: -- Error cases SELECT dateTimeToSnowflake();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:37:08.626734 [ 6234 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTimeToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:37:08.769475 [ 6234 ] {62ee0435-cd77-45dc-ac18-b9dd45c1c3f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTime64ToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40214) (comment: 01942_dateTimeToSnowflake.sql) (query 4, line 6) (in query: SELECT dateTime64ToSnowflake();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:37:08.774179 [ 6234 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTime64ToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:37:08.913272 [ 6618 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:08.916674 [ 6618 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:37:09.072779 [ 6234 ] {938e408b-92e2-4d4d-a679-106d684f976a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflake'. Expected: DateTime, got: String: In scope SELECT dateTimeToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40214) (comment: 01942_dateTimeToSnowflake.sql) (query 5, line 8) (in query: SELECT dateTimeToSnowflake('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionDateTimeToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000002085c64a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:09.178957 [ 6234 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflake'. Expected: DateTime, got: String: In scope SELECT dateTimeToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionDateTimeToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000002085c64a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:09.323898 [ 6234 ] {15cae3c0-d7dd-4ac3-9c03-d96d406d85b2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflake'. Expected: DateTime64, got: String: In scope SELECT dateTime64ToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40214) (comment: 01942_dateTimeToSnowflake.sql) (query 6, line 9) (in query: SELECT dateTime64ToSnowflake('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000002085d6ea 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:09.349401 [ 6234 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflake'. Expected: DateTime64, got: String: In scope SELECT dateTime64ToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000002085d6ea 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:09.500561 [ 6234 ] {4eeeab13-c5e5-4085-ab91-739996747cc7} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40214) (comment: 01942_dateTimeToSnowflake.sql) (query 7, line 11) (in query: SELECT dateTimeToSnowflake('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:37:09.511066 [ 6234 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:37:09.625360 [ 6234 ] {067fae00-1216-477b-a9bc-aca1ac165f21} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40214) (comment: 01942_dateTimeToSnowflake.sql) (query 8, line 12) (in query: SELECT dateTime64ToSnowflake('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:37:09.633894 [ 6234 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:37:09.853880 [ 4108 ] {3e9c7430-17ee-4a9b-a07b-be7ee6d631eb} executeQuery: Code: 36. DB::Exception: Table TTL is not allowed for MergeTree in old syntax. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40262) (comment: 01713_table_ttl_old_syntax_zookeeper.sql) (query 3, line 6) (in query: CREATE TABLE ttl_table ( date Date, value UInt64 ) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01713_table_ttl', '1', date, date, 8192) TTL date + INTERVAL 2 MONTH;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:843: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bf4d5 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:09.867261 [ 4108 ] {} TCPHandler: Code: 36. DB::Exception: Table TTL is not allowed for MergeTree in old syntax. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:843: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bf4d5 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:09.968458 [ 6234 ] {3bec4d05-d75a-4a24-820a-7b37fc44e59b} executeQuery: Code: 721. DB::Exception: Function dateTimeToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to 'true': In scope SELECT dateTimeToSnowflake(now()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40214) (comment: 01942_dateTimeToSnowflake.sql) (query 9, line 14) (in query: SELECT dateTimeToSnowflake(now()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionDateTimeToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002085c383 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:09.976904 [ 6234 ] {} TCPHandler: Code: 721. DB::Exception: Function dateTimeToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to 'true': In scope SELECT dateTimeToSnowflake(now()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionDateTimeToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002085c383 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:10.162550 [ 4108 ] {e455dd2d-a7b4-4980-acd5-75b982689eae} executeQuery: Code: 42. DB::Exception: With extended storage definition syntax storage ReplicatedMergeTree requires 0 to 2 parameters: [path in ZooKeeper], [replica name] Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40262) (comment: 01713_table_ttl_old_syntax_zookeeper.sql) (query 4, line 14) (in query: CREATE TABLE ttl_table (`date` Date, `value` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01713_table_ttl', '1', date, date, 8192) PARTITION BY date SETTINGS index_granularity = 33867, min_bytes_for_wide_part = 300520303, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 72, min_bytes_for_full_part_storage = 21059958, compact_parts_max_bytes_to_buffer = 507101689, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 15751648, merge_max_block_size = 14798, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 992266, vertical_merge_algorithm_min_columns_to_activate = 29, min_merge_bytes_to_use_direct_io = 7098150580, index_granularity_bytes = 30436908, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 16, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 86880, primary_key_compress_block_size = 36157, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x00000000311c35cf 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:500: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311be9fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:10.180686 [ 4108 ] {} TCPHandler: Code: 42. DB::Exception: With extended storage definition syntax storage ReplicatedMergeTree requires 0 to 2 parameters: [path in ZooKeeper], [replica name] Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x00000000311c35cf 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:500: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311be9fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:10.285386 [ 6234 ] {5f4aec32-f4b6-4413-8a7e-51a696195f6e} executeQuery: Code: 721. DB::Exception: Function dateTime64ToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to true: In scope SELECT dateTime64ToSnowflake(now64()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40214) (comment: 01942_dateTimeToSnowflake.sql) (query 10, line 15) (in query: SELECT dateTime64ToSnowflake(now64()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002085d401 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:10.310341 [ 6234 ] {} TCPHandler: Code: 721. DB::Exception: Function dateTime64ToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to true: In scope SELECT dateTime64ToSnowflake(now64()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002085d401 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:10.338263 [ 4108 ] {e7a0ed50-09cc-4717-a3f1-429f2585296a} executeQuery: Code: 42. DB::Exception: With extended storage definition syntax storage ReplicatedMergeTree requires 0 to 2 parameters: [path in ZooKeeper], [replica name] Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40262) (comment: 01713_table_ttl_old_syntax_zookeeper.sql) (query 5, line 22) (in query: CREATE TABLE ttl_table (`date` Date, `value` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01713_table_ttl', '1', date, date, 8192) ORDER BY value SETTINGS index_granularity = 33867, min_bytes_for_wide_part = 300520303, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 72, min_bytes_for_full_part_storage = 21059958, compact_parts_max_bytes_to_buffer = 507101689, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 15751648, merge_max_block_size = 14798, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 992266, vertical_merge_algorithm_min_columns_to_activate = 29, min_merge_bytes_to_use_direct_io = 7098150580, index_granularity_bytes = 30436908, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 16, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 86880, primary_key_compress_block_size = 36157, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x00000000311c35cf 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:500: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311be9fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:10.350063 [ 4108 ] {} TCPHandler: Code: 42. DB::Exception: With extended storage definition syntax storage ReplicatedMergeTree requires 0 to 2 parameters: [path in ZooKeeper], [replica name] Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x00000000311c35cf 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:500: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311be9fa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:10.684920 [ 7279 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:10.690316 [ 7279 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:37:12.744517 [ 6955 ] {} test_15.null_00634 (0970b4d7-5e41-49d5-8dc7-613aec0ede2f): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.13 15:37:12.745711 [ 6955 ] {} DatabaseCatalog: Cannot drop table test_15.null_00634 (0970b4d7-5e41-49d5-8dc7-613aec0ede2f). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cafe6a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030caed0f 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cbb267 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d5f99b1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d607d44 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:12.999464 [ 3931 ] {840295dd-f45b-4564-b6ec-4f6ad2be1931} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 2, should be 1: In scope SELECT BLAKE3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 4, line 4) (in query: SELECT BLAKE3(NULL, NULL);) 2025.06.13 15:37:13.030895 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 2, should be 1: In scope SELECT BLAKE3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:13.171325 [ 3931 ] {46dabd69-3b17-4529-8082-2f14e2452c55} executeQuery: Code: 43. DB::Exception: Second argument to CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 5, line 5) (in query: SELECT CAST(NULL, NULL);) 2025.06.13 15:37:13.180996 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:37:13.224269 [ 3931 ] {d23d397c-0dc9-4238-abac-8a290a10189b} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 6, line 6) (in query: SELECT CHARACTER_LENGTH(NULL, NULL);) 2025.06.13 15:37:13.236915 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:13.326394 [ 3931 ] {305417e9-c971-4a80-806a-8ff42160dfc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 7, line 7) (in query: SELECT CHAR_LENGTH(NULL, NULL);) 2025.06.13 15:37:13.332857 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:13.870745 [ 3931 ] {0610fcf5-4bf7-4fde-98fc-93cc3ab5eedb} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 2, should be 1: In scope SELECT CRC32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 10, line 10) (in query: SELECT CRC32(NULL, NULL);) 2025.06.13 15:37:13.891640 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 2, should be 1: In scope SELECT CRC32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:13.982736 [ 3931 ] {9004cb7b-6221-42cc-b645-93aedb706dc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 2, should be 1: In scope SELECT CRC32IEEE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 11, line 11) (in query: SELECT CRC32IEEE(NULL, NULL);) 2025.06.13 15:37:14.002459 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 2, should be 1: In scope SELECT CRC32IEEE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:14.109800 [ 3931 ] {64157ac9-40cd-4df3-b1d7-6ef2589af862} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 2, should be 1: In scope SELECT CRC64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 12, line 12) (in query: SELECT CRC64(NULL, NULL);) 2025.06.13 15:37:14.116628 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 2, should be 1: In scope SELECT CRC64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:14.277832 [ 3931 ] {57d2d5ae-e924-4322-bab0-d7d86f428cd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT DATABASE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 13, line 13) (in query: SELECT DATABASE(NULL, NULL);) 2025.06.13 15:37:14.332382 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT DATABASE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:14.399145 [ 6236 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:14.404037 [ 6236 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:37:14.708344 [ 5163 ] {fccaf564-4b12-4529-8188-025eb03d0544} executeQuery: Code: 1. DB::Exception: Constraint `c0` does not return a value of type UInt8. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59822) (comment: 01721_constraints_constant_expressions.sql) (query 8, line 23) (in query: INSERT INTO constraint_constant_number_expression_non_uint8 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:61: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031da1267 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:37:14.747887 [ 5163 ] {} TCPHandler: Code: 1. DB::Exception: Constraint `c0` does not return a value of type UInt8. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:61: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031da1267 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:37:15.711079 [ 5163 ] {2998479e-ebd7-4d98-a638-a3e514cf6dc0} executeQuery: Code: 469. DB::Exception: Constraint `c0` for table test_3bvrcwr2.constraint_constant_nullable_expression_that_contains_null (11cbcba1-3623-4dda-b66c-783731ed182a) is violated. Expression: (nullIf(1 % 2, 1)).Constraint expression returns nullable column that contains null value. (VIOLATED_CONSTRAINT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59822) (comment: 01721_constraints_constant_expressions.sql) (query 13, line 36) (in query: INSERT INTO constraint_constant_nullable_expression_that_contains_null VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:76: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031da1495 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:37:15.750181 [ 5163 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c0` for table test_3bvrcwr2.constraint_constant_nullable_expression_that_contains_null (11cbcba1-3623-4dda-b66c-783731ed182a) is violated. Expression: (nullIf(1 % 2, 1)).Constraint expression returns nullable column that contains null value. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:76: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031da1495 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:37:16.117204 [ 3931 ] {08d1fa6b-24db-453c-b94f-5fbe618567c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 22, line 22) (in query: SELECT FORMAT_BYTES(NULL, NULL);) 2025.06.13 15:37:16.146990 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:16.232634 [ 3931 ] {d1c57d96-c3f0-4304-b6d7-8b4708e6b5fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT FQDN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 23, line 23) (in query: SELECT FQDN(NULL, NULL);) 2025.06.13 15:37:16.248499 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT FQDN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:16.388178 [ 3931 ] {aa32d061-9b58-4f4e-81e3-ff53c8e1a2b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT FROM_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 24, line 24) (in query: SELECT FROM_BASE64(NULL, NULL);) 2025.06.13 15:37:16.414432 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT FROM_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:16.551513 [ 3931 ] {ee75c3c4-3f9a-49b5-a61e-23bc3915f1e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT FROM_DAYS(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 25, line 25) (in query: SELECT FROM_DAYS(NULL, NULL);) 2025.06.13 15:37:16.581805 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT FROM_DAYS(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:17.132698 [ 3931 ] {ef9b3523-53e7-400f-9a26-a546d4211434} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET6_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 28, line 28) (in query: SELECT INET6_ATON(NULL, NULL);) 2025.06.13 15:37:17.145060 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET6_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:17.216506 [ 5163 ] {db66c6c1-4ebc-4dcd-bba5-b482cf24a820} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 4, line 7) (in query: SELECT YYYYMMDDhhmmssToDateTime();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:37:17.249262 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:37:17.305023 [ 3931 ] {6bff93c7-6901-4f9e-be64-39b445b48d44} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT INET6_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 29, line 29) (in query: SELECT INET6_NTOA(NULL, NULL);) 2025.06.13 15:37:17.327001 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT INET6_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:17.416701 [ 5163 ] {3db16758-86b8-4cb6-91bc-525cee730bdd} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:17.420000 [ 4171 ] {8f871d46-fea9-481e-be17-660470ba41db} executeQuery: Code: 117. DB::Exception: Incorrect size of a string (zero) in BSON: (at row 6) : While executing BSONEachRowRowInputFormat. (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59930) (comment: 02686_bson3.sql) (query 1, line 1) (in query: -- It correctly throws exception about incorrect data: SELECT * FROM format(BSONEachRow, 'WatchID Int64, JavaEnable Int16, Title String, GoodEvent Int16, EventTime DateTime, EventDate Date, CounterID Int32, ClientIP Int32, RegionID Int32, UserID Int64, CounterClass Int16, OS Int16, UserAgent Int16, URL String, Referer String, IsRefresh Int16, RefererCategoryID Int16, RefererRegionID Int32, URLCategoryID Int16, URLRegionID Int32, ResolutionWidth Int16, ResolutionHeight Int16, ResolutionDepth Int16, FlashMajor Int16, FlashMinor Int16, FlashMinor2 String, NetMajor Int16, NetMinor Int16, UserAgentMajor Int16, UserAgentMinor String, CookieEnable Int16, JavascriptEnable Int16, IsMobile Int16, MobilePhone Int16, MobilePhoneModel String, Params String, IPNetworkID Int32, TraficSourceID Int16, SearchEngineID Int16, SearchPhrase String, AdvEngineID Int16, IsArtifical Int16, WindowClientWidth Int16, WindowClientHeight Int16, ClientTimeZone Int16, ClientEventTime DateTime, SilverlightVersion1 Int16, SilverlightVersion2 Int16, SilverlightVersion3 Int32, SilverlightVersion4 Int16, PageCharset String, CodeVersion Int32, IsLink Int16, IsDownload Int16, IsNotBounce Int16, FUniqID Int64, OriginalURL String, HID Int32, IsOldCounter Int16, IsEvent Int16, IsParameter Int16, DontCountHits Int16, WithHash Int16, HitColor String, LocalEventTime DateTime, Age Int16, Sex Int16, Income Int16, Interests Int16, Robotness Int16, RemoteIP Int32, WindowName Int32, OpenerName Int32, HistoryLength Int16, BrowserLanguage String, BrowserCountry String, SocialNetwork String, SocialAction String, HTTPError Int16, SendTiming Int32, DNSTiming Int32, ConnectTiming Int32, ResponseStartTiming Int32, ResponseEndTiming Int32, FetchTiming Int32, SocialSourceNetworkID Int16, SocialSourcePage String, ParamPrice Int64, ParamOrderID String, ParamCurrency String, ParamCurrencyID Int16, OpenstatServiceName String, OpenstatCampaignID String, OpenstatAdID String, OpenstatSourceID String, UTMSource String, UTMMedium String, UTMCampaign String, UTMContent String, UTMTerm String, FromTag String, HasGCLID Int16, RefererHash Int64, URLHash Int64, CLID Int32', $$^WatchIDc*5/ !p~JavaEnableTitleGoodEventEventTime7ðâQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnabl“ÿÿÿÿÿï¶sMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime&·ãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchID úFÚÓ“2qJavaEnableTitleGoodEventEventTimen$äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeǘãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageP˜amPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchIDl!è–|¨@HJavaEnableTitleGoodEventEventTimeÃ)äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime}žãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchID²Ç=ÐŒWJavaEnableTitleGoodEventEventTime8*äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeÝžãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID‹WatchIDéòˆE&LyJavaEnableTitleGoodEventEventTimeJîâQEventDate>CounterIDClientIPº‹I`RegionID'UserIDq—íJd8CounterClassOSUserAgentURL-http://holodilnik.ru/russia/05jul2013&model=0RefererIsRefreshRefererCategoryIDRefererRegionIDURLCateParams String, IPNetworkID Int32, TraficSourceID Int16, SearchEngineID Int16, SearchPhrase String, AdvEngineID Int16, IsArtifical Int16, WindowClientWidth Int16, WindowClientHeight Int16, ClientTimeZone Int16, ClientEventTime DateTime, SilverlightVersion1 Int16, SilverlightVersion2 Int16, SilverlightVersion3 Int32, SilverlightVersion4 Int16, PageCharset String, CodeVersion Int32, IsLink Int16, IsDownload Int16, IsNotBounce Int16, FUniqID Int64, OriginalURL String, HID Int32, IsOldCounter Int16, IsEvent Int16, IsParameter Int16, DontCountHits Int16, WithHash Int16, HitColor String, LocalEventTime DateTime, Age Int16, Sex Int16, Income Int16, Interests Int16, Robotness Int16, RemoteIP Int32, WindowName Int32, OpenerName Int32, HistoryLength Int16, BrowserLanguage String, BrowserCountry String, SocialNetwork String, SocialAction String, HTTPError Int16, SendTiming Int32, DNSTiming Int32, ConnectTiming Int32, ResponseStartTiming Int32, ResponseEndTiming Int32,ÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashŽ oâïòeCLID¦WatchID¹ãk=÷±pJavaEnableTitleGoodEventEventTimeÉ ãQEventDate>CounterIDClien“¶¯ÿQ9…HRegionIDGUserID ÎKs}¡ïCounterClassOSUserAgentURLHhttp://afisha.mail.ru/catalog/314/women.ru/ency=1&page3/?errovat-pinnikiRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryID0=URLRegionIDØResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4 PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqID:¤ìWëÂmOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeA¶ãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashý€ à#â\CLIDœWatchIDæ1þž oíCJavaEnableTitleGoodEventEventTimeµ0äQEventDate>CounterIDClientIPÉ^{]RegionIDÅUserID&n%Št"6CounterClassOS'UserAgentURL>http://bonprix.ru/index.ru/cinema/art/0 986 424 233 ÑезонRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionID±ResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID‰#(TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime¼£ãQAgeSexIncomeInterestsRobotnessRemoteIP…UWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashX-h³ýX CLID˜WatchID»-ÞC_JavaEnableTitleGoodEventEventTime83äQEventDate>CounterIDClientIPÉ^{]RegionIDÅUserID&n%Št"6CounterClassOS'UserAgentURL:http://bonprix.ru/index.ru/cinema/art/A00387,3797); ru)&bLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionID±ResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID‰#(TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime ¦ãQAgeSexIncomeInterestsRobotnessRemoteIP…UWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashvÀvÍÀ‰ÇCLIDWatchIDìÒŒ\JavaEnableTitleGoodEventEventTime× äQEventDate>CounterIDClientIPgURegionIDåUserIDƒs—yyçófCounterClassOS,UserAgentURL1http://tours/Ekategoriya%2F&sr=http://slovareniyeRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDØesRolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajor UserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¶œTraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeY’ãQAgeSexIncomeInterestsRobotnessRemoteIP€=kWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashh˜´9›DCLID^WatchIDÛ/E‚ÜJÛ{JavaEnableTitleGoodEventEventTimeÖ1ãQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhkneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime‹ÏãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID$$);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:286: void DB::readAndInsertString(DB::ReadBuffer&, DB::IColumn&, DB::BSONType) @ 0x00000000319283c3 6. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:626: DB::BSONEachRowRowInputFormat::readField(DB::IColumn&, std::shared_ptr const&, DB::BSONType) @ 0x000000003191e7fa 7. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:809: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003192a86f 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 19. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:37:17.440728 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:17.445221 [ 4171 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect size of a string (zero) in BSON: (at row 6) : While executing BSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:286: void DB::readAndInsertString(DB::ReadBuffer&, DB::IColumn&, DB::BSONType) @ 0x00000000319283c3 6. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:626: DB::BSONEachRowRowInputFormat::readField(DB::IColumn&, std::shared_ptr const&, DB::BSONType) @ 0x000000003191e7fa 7. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:809: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003192a86f 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 19. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:37:17.571322 [ 3931 ] {cfa4c335-1fc1-42a3-a4a8-2bb5743f4dc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 30, line 30) (in query: SELECT INET_ATON(NULL, NULL);) 2025.06.13 15:37:17.584894 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:17.632422 [ 5163 ] {0f81de3b-6c93-47f9-b311-8a5696409419} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:17.706036 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:17.718977 [ 3931 ] {831063dc-4bcf-4397-87a8-0c7e2dde6f32} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT INET_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 31, line 31) (in query: SELECT INET_NTOA(NULL, NULL);) 2025.06.13 15:37:17.780862 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT INET_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:17.836440 [ 5163 ] {12424337-1e96-4fc2-aa0b-4821de18db44} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:17.849176 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:17.976600 [ 6953 ] {} test_15.null_00634 (0970b4d7-5e41-49d5-8dc7-613aec0ede2f): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.13 15:37:17.978260 [ 6953 ] {} DatabaseCatalog: Cannot drop table test_15.null_00634 (0970b4d7-5e41-49d5-8dc7-613aec0ede2f). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cafe6a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030caed0f 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cbb267 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d5f99b1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d607d44 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:18.015075 [ 5163 ] {7eb8a8c4-9a20-4eaf-a1c8-57a77b8e1503} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:18.019287 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:18.059463 [ 5163 ] {b5d461c4-8a21-49a4-a32e-f3490bce42e1} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:18.067027 [ 3931 ] {f6bd2865-6f5f-4418-b1b6-ec9ef6bc5dbf} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 33, line 33) (in query: SELECT IPv4NumToString(NULL, NULL);) 2025.06.13 15:37:18.084009 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:18.084676 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:18.219540 [ 3931 ] {a6fa0f23-1504-44fd-a394-21ec3abbbc59} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 34, line 34) (in query: SELECT IPv4NumToStringClassC(NULL, NULL);) 2025.06.13 15:37:18.236788 [ 5163 ] {d4d95feb-e9fb-4d3c-a816-0ebdb069b5f4} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:37:18.251601 [ 6155 ] {0d9978a7-0f24-4e54-9d43-10417a4164e9} executeQuery: Code: 36. DB::Exception: Cannot reset setting 'ttl' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59954) (comment: 02252_reset_non_existing_setting.sql) (query 3, line 10) (in query: ALTER TABLE most_ordinary_mt RESET SETTING ttl;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3787: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cca6a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:37:18.273821 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:37:18.282140 [ 6155 ] {} TCPHandler: Code: 36. DB::Exception: Cannot reset setting 'ttl' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3787: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cca6a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:37:18.282679 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:18.360399 [ 6155 ] {ee4f0c1e-4532-41d7-bb1e-00e90c5a46f9} executeQuery: Code: 36. DB::Exception: Cannot reset setting 'xxx' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59954) (comment: 02252_reset_non_existing_setting.sql) (query 4, line 11) (in query: ALTER TABLE most_ordinary_mt RESET SETTING allow_remote_fs_zero_copy_replication, xxx;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3787: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cca6a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:37:18.364736 [ 3931 ] {e6fbddda-b32e-4168-aaf5-dfce1e15db86} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 35, line 35) (in query: SELECT IPv4StringToNum(NULL, NULL);) 2025.06.13 15:37:18.364874 [ 6155 ] {} TCPHandler: Code: 36. DB::Exception: Cannot reset setting 'xxx' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3787: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cca6a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:37:18.387306 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:18.462989 [ 3931 ] {1766c941-93f1-4da6-8974-9b5dcac47d8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 36, line 36) (in query: SELECT IPv4StringToNumOrDefault(NULL, NULL);) 2025.06.13 15:37:18.518503 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:18.526770 [ 5163 ] {5325a3cf-1a33-4f70-bb2f-d9873867dbf1} executeQuery: Code: 36. DB::Exception: Cannot load time zone invalid tz: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'invalid tz'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c8502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c3635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c4015e8 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c400f59 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&) @ 0x0000000019eb56d9 10. std::shared_ptr std::allocate_shared[abi:ne190107], String&, 0>(std::allocator const&, String&) @ 0x0000000019eb54e0 11. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdbc5 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:18.565998 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c8502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c3635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c4015e8 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c400f59 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&) @ 0x0000000019eb56d9 10. std::shared_ptr std::allocate_shared[abi:ne190107], String&, 0>(std::allocator const&, String&) @ 0x0000000019eb54e0 11. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdbc5 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:18.658680 [ 5163 ] {274c103a-f567-4910-8000-47af9b3f6553} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:37:18.680805 [ 3931 ] {18c2ba95-4ec2-428a-9ecd-03b6519db869} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 37, line 37) (in query: SELECT IPv4StringToNumOrNull(NULL, NULL);) 2025.06.13 15:37:18.689025 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccdaed 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:37:18.708162 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:18.863137 [ 3931 ] {96b66101-acb0-4867-9b22-1f8347092ccc} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 2, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 38, line 38) (in query: SELECT IPv4ToIPv6(NULL, NULL);) 2025.06.13 15:37:18.874394 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 2, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:19.176408 [ 3931 ] {e16c4416-df8e-4285-a812-72561d54a73d} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv6NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 40, line 40) (in query: SELECT IPv6NumToString(NULL, NULL);) 2025.06.13 15:37:19.207354 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv6NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:19.387063 [ 3931 ] {ff636bc4-db60-45ba-b1ff-aff2b34a04c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 41, line 41) (in query: SELECT IPv6StringToNum(NULL, NULL);) 2025.06.13 15:37:19.398218 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:19.489835 [ 3931 ] {64b9d96f-6bc4-4ad4-9ab6-7505e9b408f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 42, line 42) (in query: SELECT IPv6StringToNumOrDefault(NULL, NULL);) 2025.06.13 15:37:19.528273 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:19.686088 [ 3931 ] {83a818da-2d15-4c5c-a675-7a9c5bc30eb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 43, line 43) (in query: SELECT IPv6StringToNumOrNull(NULL, NULL);) 2025.06.13 15:37:19.696002 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:19.709287 [ 4098 ] {0c708d9f-2e42-4ec9-8e77-3bfa1a847587} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different values of constants in column '1': actual: 1, expected: 3. (AMBIGUOUS_COLUMN_NAME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59970) (comment: 01101_literal_column_clash.sql) (query 5, line 10) (in query: with 3 as "1" select 1, "1";), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x000000002c09166f 5. ./build_docker/./src/Core/Block.cpp:41: void DB::onError>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x000000002c08b471 6. ./build_docker/./src/Core/Block.cpp:102: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002c07f7a7 7. ./build_docker/./src/Core/Block.cpp:202: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002c07fa6d 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:464: DB::ExpressionActions::linearizeActions(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002d61f5a8 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:65: DB::ExpressionActions::ExpressionActions(DB::ActionsDAG, DB::ExpressionActionsSettings const&, bool) @ 0x000000002d61ec65 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ExpressionActions* std::construct_at[abi:ne190107](DB::ExpressionActions*, DB::ActionsDAG&&, DB::ExpressionActionsSettings const&) @ 0x000000002cb8496a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, DB::ActionsDAG&&, DB::ExpressionActionsSettings const&) @ 0x000000002cb8477f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::ActionsDAG, DB::ExpressionActionsSettings const&, 0>(std::allocator const&, DB::ActionsDAG&&, DB::ExpressionActionsSettings const&) @ 0x000000002cb84600 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::ExpressionStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000320ec7a4 14. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000032115740 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:37:19.721127 [ 4098 ] {} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different values of constants in column '1': actual: 1, expected: 3. (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x000000002c09166f 5. ./build_docker/./src/Core/Block.cpp:41: void DB::onError>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x000000002c08b471 6. ./build_docker/./src/Core/Block.cpp:102: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002c07f7a7 7. ./build_docker/./src/Core/Block.cpp:202: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002c07fa6d 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:464: DB::ExpressionActions::linearizeActions(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002d61f5a8 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:65: DB::ExpressionActions::ExpressionActions(DB::ActionsDAG, DB::ExpressionActionsSettings const&, bool) @ 0x000000002d61ec65 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ExpressionActions* std::construct_at[abi:ne190107](DB::ExpressionActions*, DB::ActionsDAG&&, DB::ExpressionActionsSettings const&) @ 0x000000002cb8496a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, DB::ActionsDAG&&, DB::ExpressionActionsSettings const&) @ 0x000000002cb8477f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::ActionsDAG, DB::ExpressionActionsSettings const&, 0>(std::allocator const&, DB::ActionsDAG&&, DB::ExpressionActionsSettings const&) @ 0x000000002cb84600 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::ExpressionStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000320ec7a4 14. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000032115740 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:37:19.809643 [ 3931 ] {61be9582-f533-4b63-8617-96ff1c45f1af} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 2, should be 1: In scope SELECT JSONAllPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 44, line 44) (in query: SELECT JSONAllPaths(NULL, NULL);) 2025.06.13 15:37:19.828921 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 2, should be 1: In scope SELECT JSONAllPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:19.991535 [ 3931 ] {432603b2-d559-4b51-94ec-90b8f160c2cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 45, line 45) (in query: SELECT JSONAllPathsWithTypes(NULL, NULL);) 2025.06.13 15:37:19.997967 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:20.074197 [ 3931 ] {9eead554-f4c6-4fd9-b262-258223dd6dcf} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSONArrayLength(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 46, line 46) (in query: SELECT JSONArrayLength(NULL, NULL);) 2025.06.13 15:37:20.088702 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSONArrayLength(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:20.282412 [ 3931 ] {6f691193-5b5c-4d40-991e-a0dacf9e1312} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 47, line 47) (in query: SELECT JSONDynamicPaths(NULL, NULL);) 2025.06.13 15:37:20.319784 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:20.455463 [ 3931 ] {5fb0bcfd-3538-48c1-893e-4486bc30d381} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 48, line 48) (in query: SELECT JSONDynamicPathsWithTypes(NULL, NULL);) 2025.06.13 15:37:20.461824 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:20.567680 [ 3931 ] {b476e547-01eb-4473-a7a9-1de6cd3a167b} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 49, line 49) (in query: SELECT JSONExtract(NULL, NULL);) 2025.06.13 15:37:20.576744 [ 3931 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL). (ILLEGAL_COLUMN) 2025.06.13 15:37:21.215649 [ 3982 ] {47b85a2a-9984-4cb8-9be5-d8c72cd3c56c} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60070.282221 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40056) (comment: 00906_low_cardinality_cache.sql) (query 4, line 6) (in query: insert into lc_00906 select '0123456789' from numbers(100000000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:21.297111 [ 3982 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60070.282221 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:37:21.455494 [ 3505 ] {ea4e84ed-e301-4360-b2b8-faf454dc77e7::all_66_70_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030c4f297 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3acd74 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 13. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1afd8 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 16. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:21.459972 [ 3506 ] {ea4e84ed-e301-4360-b2b8-faf454dc77e7::all_1_25_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:21.468588 [ 3499 ] {ea4e84ed-e301-4360-b2b8-faf454dc77e7::all_61_65_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:21.511208 [ 3931 ] {78cbad6c-656f-4e2f-82e7-c62e71ce61f7} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 55, line 55) (in query: SELECT JSONExtractKeysAndValues(NULL, NULL);) 2025.06.13 15:37:21.520343 [ 4098 ] {63c496f1-43e7-4b49-a449-02fa89fb3774} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in JOIN ON expression [Predcates: ()]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59970) (comment: 01101_literal_column_clash.sql) (query 10, line 18) (in query: -- other cases with joins and constants select cast(1, 'UInt8') from (select arrayJoin([1, 2]) as a) t1 left join (select 1 as b) t2 on b = ignore('UInt8');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:572: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213e667 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:37:21.528191 [ 3931 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL). (ILLEGAL_COLUMN) 2025.06.13 15:37:21.538388 [ 4098 ] {} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in JOIN ON expression [Predcates: ()]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:572: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213e667 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:37:21.755034 [ 6955 ] {} test_uh1bdtpm.lc_00906 (ea4e84ed-e301-4360-b2b8-faf454dc77e7): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.13 15:37:21.819635 [ 4098 ] {a5cc0960-0c2a-4810-b5ef-ed69b96b2290} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in JOIN ON expression [Predcates: ()]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59970) (comment: 01101_literal_column_clash.sql) (query 11, line 22) (in query: select isConstant('UInt8'), toFixedString('hello', toUInt8(substring('UInt8', 5, 1))) from (select arrayJoin([1, 2]) as a) t1 left join (select 1 as b) t2 on b = ignore('UInt8');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:572: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213e667 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:37:21.840696 [ 6955 ] {} DatabaseCatalog: Cannot drop table test_uh1bdtpm.lc_00906 (ea4e84ed-e301-4360-b2b8-faf454dc77e7). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cafe6a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030caed0f 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cbb267 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d5f99b1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d607d44 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:21.847895 [ 6155 ] {cd8255ee-2079-4ea5-9ba0-28c4d76b830e} executeQuery: Code: 182. DB::Exception: Table expression test_9.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.20286.altinityantalya (altinity build)) (from [::1]:59996) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15d80f 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15cdb6 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15cdb6 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15cdb6 9. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15cdb6 10. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x000000002d158eee 11. ./build_docker/./src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6bb69 12. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:37:21.851504 [ 4098 ] {} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in JOIN ON expression [Predcates: ()]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:572: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213e667 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:37:21.855683 [ 7778 ] {726dca81-959d-4248-9c95-2df6ccb8c0dc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36286) (comment: 02346_fulltext_index_detach_attach.sql) (in query: DROP DATABASE IF EXISTS test_79jtpr7x SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:21.860237 [ 7778 ] {726dca81-959d-4248-9c95-2df6ccb8c0dc} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:21.866179 [ 6155 ] {} TCPHandler: Code: 182. DB::Exception: Table expression test_9.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15d80f 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15cdb6 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15cdb6 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15cdb6 9. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15cdb6 10. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x000000002d158eee 11. ./build_docker/./src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6bb69 12. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:37:21.917609 [ 6234 ] {3669a5bc-b549-4dbe-9e2a-7868bb767869} 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.20286.altinityantalya (altinity build)) (from [::1]:59922) (comment: 01018_ddl_dictionaries_select.sql) (query 13, line 39) (in query: DETACH DICTIONARY test_5.dict1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c773b3d 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:21.942618 [ 6234 ] {} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1106: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c773b3d 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:22.393940 [ 5163 ] {56f06e95-2339-46ab-8752-e22de6b1f8be} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(nan). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dccd7ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:22.491361 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dccd7ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:22.517798 [ 6219 ] {e3c5dc51-ae94-4406-b3b2-c46a722ecfc6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=812, jobs=783). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34646) (comment: 00623_truncate_table.sql) (query 66, line 72) (in query: DROP TABLE IF EXISTS truncate_test_stripe_log;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:37:22.536083 [ 6219 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=812, jobs=783). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:37:22.580223 [ 5163 ] {0ff05b9d-5cbd-4790-a405-0636d2aebd1d} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(inf). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dccd7ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:22.602891 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dccd7ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:22.724529 [ 5163 ] {01d8d854-cbcb-4272-913c-b28aa6aaffa3} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(-inf). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dccd7ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:22.729360 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dccd7ef 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:23.167869 [ 6219 ] {17378961-9c2d-4ac0-b088-b920cbad065f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36488) (comment: 02293_selected_rows_and_merges.sh) (in query: DROP DATABASE IF EXISTS test_ae9niz3r SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:23.172471 [ 6219 ] {17378961-9c2d-4ac0-b088-b920cbad065f} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:23.289881 [ 4171 ] {1c871dbe-a940-48a7-af79-ce368d5d6647} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36504) (comment: 02293_selected_rows_and_merges.sh) (in query: DROP DATABASE IF EXISTS test_ae9niz3r SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:23.292729 [ 3931 ] {6a06cee0-ddc6-492e-bd49-f0156b6e3bb5} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 64, line 64) (in query: SELECT JSONSharedDataPaths(NULL, NULL);) 2025.06.13 15:37:23.293533 [ 4171 ] {1c871dbe-a940-48a7-af79-ce368d5d6647} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:23.316928 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:23.495955 [ 3931 ] {512eb8e9-edb6-4943-858c-b3a48a4a1ff5} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 65, line 65) (in query: SELECT JSONSharedDataPathsWithTypes(NULL, NULL);) 2025.06.13 15:37:23.500756 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:23.849537 [ 3931 ] {a6fa5aff-8a40-4bcf-9278-95341793083b} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 67, line 67) (in query: SELECT JSON_ARRAY_LENGTH(NULL, NULL);) 2025.06.13 15:37:23.858774 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:24.651824 [ 3931 ] {fcd30a55-9330-4f1f-9f99-eba4cd847db0} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT L1Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 72, line 72) (in query: SELECT L1Norm(NULL, NULL);) 2025.06.13 15:37:24.686709 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT L1Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:24.798341 [ 3931 ] {fc120398-bda1-48f2-815c-e373f6123181} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT L1Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 73, line 73) (in query: SELECT L1Normalize(NULL, NULL);) 2025.06.13 15:37:24.810068 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT L1Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:25.214915 [ 3931 ] {d2a24ba2-3c20-415e-91a4-4f47fb9fa122} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT L2Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 75, line 75) (in query: SELECT L2Norm(NULL, NULL);) 2025.06.13 15:37:25.260591 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT L2Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:25.433431 [ 3931 ] {12a98a2b-168b-4cfd-87e7-ce189ccd908a} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT L2Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 76, line 76) (in query: SELECT L2Normalize(NULL, NULL);) 2025.06.13 15:37:25.451476 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT L2Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:25.792804 [ 3931 ] {f92dd42e-5e82-410d-b93c-3859dbeb5e91} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 78, line 78) (in query: SELECT L2SquaredNorm(NULL, NULL);) 2025.06.13 15:37:25.802626 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:25.991218 [ 6155 ] {f8197e11-01c9-4c19-85e1-82f7ea1814b4} 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.20286.altinityantalya (altinity build)) (from [::1]:60048) (comment: 00607_index_in_in.sql) (query 10, line 13) (in query: SELECT count() FROM merge_tree WHERE toUInt32(x) IN (0, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:26.024066 [ 6155 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:26.202841 [ 5978 ] {d1024f22-5f5e-4087-b503-7bdc3aa8499f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36526) (comment: 00607_index_in_in.sql) (in query: DROP DATABASE IF EXISTS test_gwb436dh SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:26.224688 [ 5978 ] {d1024f22-5f5e-4087-b503-7bdc3aa8499f} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:26.325622 [ 3931 ] {620c672b-a41f-44b1-ae32-6f3713a7523a} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT LinfNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 81, line 81) (in query: SELECT LinfNorm(NULL, NULL);) 2025.06.13 15:37:26.346143 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT LinfNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:26.469609 [ 3931 ] {ae6dffde-d9d2-46f6-811b-a06c513deb3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT LinfNormalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 82, line 82) (in query: SELECT LinfNormalize(NULL, NULL);) 2025.06.13 15:37:26.504403 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT LinfNormalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:26.634216 [ 3931 ] {06aa3bb3-3549-48de-bfd7-0ef2eb5fd0c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 83, line 83) (in query: SELECT LpDistance(NULL, NULL);) 2025.06.13 15:37:26.652500 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:27.333171 [ 3931 ] {3ca8f29b-7a25-42b1-ab56-9c895fbadf69} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 2, should be 1: In scope SELECT MACNumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 86, line 86) (in query: SELECT MACNumToString(NULL, NULL);) 2025.06.13 15:37:27.360947 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 2, should be 1: In scope SELECT MACNumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:27.489117 [ 3931 ] {07a63535-785f-43de-8ea1-93a8793a3c9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 2, should be 1: In scope SELECT MACStringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 87, line 87) (in query: SELECT MACStringToNum(NULL, NULL);) 2025.06.13 15:37:27.489334 [ 5163 ] {2a6cd2c7-3d92-4f61-80d9-9d59fda9eee0} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (query 58, line 69) (in query: SELECT YYYYMMDDhhmmssToDateTime64();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:37:27.504470 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:37:27.508359 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 2, should be 1: In scope SELECT MACStringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:27.632975 [ 5005 ] {49e4b710-22c5-41c9-9145-0944b3813a86} executeQuery: Code: 388. DB::Exception: Cannot select parts for optimization: there are no parts in partition 123. (CANNOT_ASSIGN_OPTIMIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40204) (comment: 02439_merge_selecting_partitions.sql) (query 14, line 20) (in query: optimize table rmt partition tuple(123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6144: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x000000003067a654 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6306: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000030675808 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:37:27.643685 [ 5005 ] {} TCPHandler: Code: 388. DB::Exception: Cannot select parts for optimization: there are no parts in partition 123. (CANNOT_ASSIGN_OPTIMIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6144: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x000000003067a654 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6306: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000030675808 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:37:27.655560 [ 3931 ] {6989e0ec-f39c-40d6-9008-ad87fda7cddd} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 2, should be 1: In scope SELECT MACStringToOUI(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 88, line 88) (in query: SELECT MACStringToOUI(NULL, NULL);) 2025.06.13 15:37:27.674496 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 2, should be 1: In scope SELECT MACStringToOUI(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:27.705993 [ 5163 ] {5dd31aca-6ebe-48ef-8384-e8bd9409a2f5} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:27.720796 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:27.862053 [ 5163 ] {51de932b-8ea4-4b90-97e7-0e3a23b09de7} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:27.869617 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:28.008638 [ 5163 ] {2a3eac85-3bdf-405e-b20f-d49a11847f29} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:28.012092 [ 3931 ] {ae813609-625a-471f-b6fb-14cd364f0af8} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 2, should be 1: In scope SELECT MD4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 90, line 90) (in query: SELECT MD4(NULL, NULL);) 2025.06.13 15:37:28.025384 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:28.035257 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 2, should be 1: In scope SELECT MD4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:28.136288 [ 3931 ] {2e848cce-ddfa-414b-824c-fbfc8b507ded} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 2, should be 1: In scope SELECT MD5(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 91, line 91) (in query: SELECT MD5(NULL, NULL);) 2025.06.13 15:37:28.140877 [ 5163 ] {6f6c3b8c-b29a-474b-828c-0c7b99403c79} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:28.153820 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 2, should be 1: In scope SELECT MD5(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:28.155461 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:28.276392 [ 5163 ] {0f780a9f-ceed-4ca6-9741-b524e1a43dc5} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:28.284568 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:28.346853 [ 6253 ] {32cbe5ef-eba6-411b-b16c-f0c1a424db76} executeQuery: Code: 581. DB::Exception: Maximum distributed depth exceeded. (TOO_LARGE_DISTRIBUTED_DEPTH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:45394) (comment: 02224_parallel_distributed_insert_select_cluster.sql) (query 7, line 9) (in query: INSERT INTO FUNCTION cluster('test_cluster_two_shards', 'test_vrpbanei', 'dst_02224', `key`) SETTINGS parallel_distributed_insert_select = 1, max_distributed_depth = 1 SELECT * FROM `test_vrpbanei`.`src_02224` SETTINGS parallel_distributed_insert_select = 1, max_distributed_depth = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1208: DB::StorageDistributed::distributedWrite(DB::ASTInsertQuery const&, std::shared_ptr) @ 0x000000003039ac51 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:858: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5e0e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:37:28.369857 [ 6253 ] {} TCPHandler: Code: 581. DB::Exception: Maximum distributed depth exceeded. (TOO_LARGE_DISTRIBUTED_DEPTH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1208: DB::StorageDistributed::distributedWrite(DB::ASTInsertQuery const&, std::shared_ptr) @ 0x000000003039ac51 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:858: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5e0e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:37:28.397953 [ 6155 ] {4caf8e9e-8d25-4879-a3ca-d8946038e76f} executeQuery: Code: 581. DB::Exception: Maximum distributed depth exceeded. (TOO_LARGE_DISTRIBUTED_DEPTH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47488) (comment: 02224_parallel_distributed_insert_select_cluster.sql) (query 7, line 9) (in query: INSERT INTO FUNCTION cluster('test_cluster_two_shards', 'test_vrpbanei', 'dst_02224', `key`) SETTINGS parallel_distributed_insert_select = 1, max_distributed_depth = 1 SELECT * FROM `test_vrpbanei`.`src_02224` SETTINGS parallel_distributed_insert_select = 1, max_distributed_depth = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1208: DB::StorageDistributed::distributedWrite(DB::ASTInsertQuery const&, std::shared_ptr) @ 0x000000003039ac51 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:858: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5e0e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:37:28.410943 [ 6155 ] {} TCPHandler: Code: 581. DB::Exception: Maximum distributed depth exceeded. (TOO_LARGE_DISTRIBUTED_DEPTH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1208: DB::StorageDistributed::distributedWrite(DB::ASTInsertQuery const&, std::shared_ptr) @ 0x000000003039ac51 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:858: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5e0e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:37:28.427230 [ 6234 ] {dbef4acc-5766-4394-a980-09aa90872420} executeQuery: Code: 581. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Maximum distributed depth exceeded. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1208: DB::StorageDistributed::distributedWrite(DB::ASTInsertQuery const&, std::shared_ptr) @ 0x000000003039ac51 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:858: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5e0e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 : While executing Remote. (TOO_LARGE_DISTRIBUTED_DEPTH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52926) (comment: 02224_parallel_distributed_insert_select_cluster.sql) (query 7, line 9) (in query: insert into function cluster('test_cluster_two_shards', currentDatabase(), dst_02224, key) select * from cluster('test_cluster_two_shards', currentDatabase(), src_02224, key) settings parallel_distributed_insert_select=1, max_distributed_depth=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:37:28.432557 [ 5163 ] {c1fbee9a-4ebc-4c0a-b159-424aeb2233ff} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:28.437308 [ 6234 ] {} TCPHandler: Code: 581. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Maximum distributed depth exceeded. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1208: DB::StorageDistributed::distributedWrite(DB::ASTInsertQuery const&, std::shared_ptr) @ 0x000000003039ac51 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:858: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5e0e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 : While executing Remote. (TOO_LARGE_DISTRIBUTED_DEPTH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:37:28.456665 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:37:28.671621 [ 5163 ] {24dceeb1-46bb-4374-af77-1cb7bcaba1c2} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:37:28.689811 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:37:28.940368 [ 5163 ] {0780f207-1e25-43f4-81b2-37ba17ecddc6} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c8502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c3635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c4015e8 8. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402137 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&) @ 0x000000001dcd007b 10. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String&, 0>(std::allocator const&, unsigned int&, String&) @ 0x000000001dccfe86 11. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf31e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:28.961006 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c8502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c3635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c4015e8 8. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402137 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&) @ 0x000000001dcd007b 10. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String&, 0>(std::allocator const&, unsigned int&, String&) @ 0x000000001dccfe86 11. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf31e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:28.968148 [ 3931 ] {38867218-a797-4fbf-8950-986063ebba6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 95, line 95) (in query: SELECT OCTET_LENGTH(NULL, NULL);) 2025.06.13 15:37:29.033154 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:29.064090 [ 5163 ] {28d96a23-386e-41fe-b61d-e5c1051d0e12} 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.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:37:29.077583 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002ad0beaf 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08cbf 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dccf166 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:37:29.126590 [ 5978 ] {f596f8fc-0ae4-4e2d-815d-0bb0c0692a02} executeQuery: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 1, line 4) (in query: SELECT * FROM url('http://localhost:8123/', LineAsString, headers('exact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:24: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028987121 6. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f36c3 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d40be 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3c86 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3a7a 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d15b5 11. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:29.139313 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:24: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028987121 6. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f36c3 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d40be 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3c86 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3a7a 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d15b5 11. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:29.492387 [ 5978 ] {35b6683e-88ff-4c53-beb6-f907cd85426d} executeQuery: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 2, line 5) (in query: SELECT * FROM url('http://localhost:8123/', LineAsString, headers('cAsE_INSENSITIVE_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028986fef 6. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f36c3 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d40be 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3c86 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3a7a 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d15b5 11. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:29.513701 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028986fef 6. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f36c3 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d40be 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3c86 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3a7a 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d15b5 11. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:29.734586 [ 5978 ] {dfa9c0eb-dacd-46e8-827a-f9f4b6a1d5f5} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 3, line 6) (in query: SELECT * FROM url('http://localhost:8123/', LineAsString, headers('bad_header_name: test\nexact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f36c3 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d40be 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3c86 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3a7a 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d15b5 11. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:29.813473 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f36c3 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d40be 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3c86 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3a7a 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d15b5 11. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:29.892267 [ 7778 ] {40ed8bf1-569a-4248-a91d-5af64ab03904} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Variant(String, UInt64), UInt8) of function equals: In scope SELECT * FROM test WHERE v = 42. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52940) (comment: 02990_variant_where_cond.sql) (query 5, line 7) (in query: select * from test where v = 42;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6e5dd9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:37:29.925509 [ 7778 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Variant(String, UInt64), UInt8) of function equals: In scope SELECT * FROM test WHERE v = 42. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6e5dd9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:37:30.097031 [ 5978 ] {12c5e845-98f6-43fc-b1e7-824d97ad3505} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 4, line 7) (in query: SELECT * FROM url('http://localhost:8123/', LineAsString, headers('bad_header_value' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f36c3 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d40be 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3c86 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3a7a 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d15b5 11. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:30.107531 [ 3931 ] {109201ad-e20e-4f3a-a3a2-31841234514d} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT REGEXP_REPLACE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 99, line 99) (in query: SELECT REGEXP_REPLACE(NULL, NULL);) 2025.06.13 15:37:30.148856 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f36c3 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, DB::StorageURL*>(DB::StorageURL*, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d40be 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3c86 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000284d3a7a 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d15b5 11. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:30.159447 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT REGEXP_REPLACE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:30.289868 [ 3931 ] {a83b48be-ca04-4c00-a8e0-d48d4c28aecb} executeQuery: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 2, should be 1: In scope SELECT RIPEMD160(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 100, line 100) (in query: SELECT RIPEMD160(NULL, NULL);) 2025.06.13 15:37:30.314653 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 2, should be 1: In scope SELECT RIPEMD160(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:30.546062 [ 3931 ] {da0e99e9-966f-4a53-bfe6-0b4954a2a29f} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT SCHEMA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 101, line 101) (in query: SELECT SCHEMA(NULL, NULL);) 2025.06.13 15:37:30.562987 [ 6193 ] {6cf555af-4420-4495-851e-99a6b425fa6b} executeQuery: Code: 70. DB::Exception: Cannot convert type UInt8 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT __table1.v AS v FROM test_531v60dc.test AS __table1 WHERE __table1.v = _CAST(42, 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:33390) (comment: 02990_variant_where_cond.sql) (query 6, line 8) (in query: SELECT `__table1`.`v` AS `v` FROM `test_531v60dc`.`test` AS `__table1` WHERE `__table1`.`v` = _CAST(42, 'Variant(String, UInt64)')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x000000002ad8d727 6. DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad807f2 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad7e61b 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad7db23 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3557: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc30615 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002cca56b5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002cca5476 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e18 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:30.563283 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT SCHEMA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:30.598613 [ 6193 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert type UInt8 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT __table1.v AS v FROM test_531v60dc.test AS __table1 WHERE __table1.v = _CAST(42, 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x000000002ad8d727 6. DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad807f2 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad7e61b 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad7db23 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3557: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc30615 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002cca56b5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002cca5476 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e18 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:30.836792 [ 4930 ] {8a14c0cb-5b49-478e-b524-03f76b116275} executeQuery: Code: 70. DB::Exception: Cannot convert type UInt8 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT __table1.v AS v FROM test_531v60dc.test AS __table1 WHERE __table1.v = _CAST(42, 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:58912) (comment: 02990_variant_where_cond.sql) (query 6, line 8) (in query: SELECT `__table1`.`v` AS `v` FROM `test_531v60dc`.`test` AS `__table1` WHERE `__table1`.`v` = _CAST(42, 'Variant(String, UInt64)')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x000000002ad8d727 6. DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad807f2 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad7e61b 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad7db23 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3557: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc30615 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002cca56b5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002cca5476 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e18 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:30.888439 [ 4930 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert type UInt8 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT __table1.v AS v FROM test_531v60dc.test AS __table1 WHERE __table1.v = _CAST(42, 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x000000002ad8d727 6. DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad807f2 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad7e61b 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad7db23 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3557: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc30615 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002cca56b5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002cca5476 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e18 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:30.977495 [ 5978 ] {732d1b35-1049-4ffa-b2eb-32f78f25cd8a} executeQuery: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 6, line 10) (in query: SELECT * FROM urlCluster('test_cluster_two_shards_localhost', 'http://localhost:8123/', LineAsString, headers('exact_header' = 'value'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:24: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028987121 6. ./build_docker/./src/Storages/StorageURLCluster.cpp:58: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003080a7af 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, std::allocator, 0>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d32c5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d30ce 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d543e 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 12. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:31.004604 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:24: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028987121 6. ./build_docker/./src/Storages/StorageURLCluster.cpp:58: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003080a7af 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, std::allocator, 0>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d32c5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d30ce 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d543e 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 12. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:31.130218 [ 7755 ] {e1370dc0-49a8-48a7-9008-4b0222edd6e4} executeQuery: Code: 70. DB::Exception: Cannot convert type UInt8 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT __table1.v AS v FROM test_531v60dc.test AS __table1 WHERE __table1.v = _CAST(42, 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:46432) (comment: 02990_variant_where_cond.sql) (query 6, line 8) (in query: SELECT `__table1`.`v` AS `v` FROM `test_531v60dc`.`test` AS `__table1` WHERE `__table1`.`v` = _CAST(42, 'Variant(String, UInt64)')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x000000002ad8d727 6. DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad807f2 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad7e61b 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad7db23 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3557: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc30615 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002cca56b5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002cca5476 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e18 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:31.155091 [ 7755 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert type UInt8 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT __table1.v AS v FROM test_531v60dc.test AS __table1 WHERE __table1.v = _CAST(42, 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x000000002ad8d727 6. DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad807f2 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad7e61b 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad7db23 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3557: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc30615 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002cca56b5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002cca5476 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e18 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:31.176418 [ 7778 ] {9ab4de86-82c1-4b0d-8b1e-ae78602e4736} executeQuery: Code: 70. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot convert type UInt8 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT __table1.v AS v FROM test_531v60dc.test AS __table1 WHERE __table1.v = _CAST(42, 'Variant(String, UInt64)'). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x000000002ad8d727 6. DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad807f2 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad7e61b 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad7db23 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3557: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc30615 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002cca56b5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002cca5476 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e18 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae : While executing Remote. (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52940) (comment: 02990_variant_where_cond.sql) (query 6, line 8) (in query: select * from test where v = 42::UInt64::Variant(String, UInt64);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:37:31.177271 [ 3931 ] {7991b2af-a695-4889-9af1-47b90a88e17c} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 2, should be 1: In scope SELECT SHA1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 103, line 103) (in query: SELECT SHA1(NULL, NULL);) 2025.06.13 15:37:31.210797 [ 7778 ] {} TCPHandler: Code: 70. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot convert type UInt8 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT __table1.v AS v FROM test_531v60dc.test AS __table1 WHERE __table1.v = _CAST(42, 'Variant(String, UInt64)'). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x000000002ad8d727 6. DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad807f2 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002ad7e61b 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002ad7db23 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3557: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc30615 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002cca56b5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002cca5476 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e18 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae : While executing Remote. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:31.213760 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 2, should be 1: In scope SELECT SHA1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:31.359105 [ 3500 ] {406808e3-2a20-42a6-8721-3119debca6ac::202506_1_36_7} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c14c18 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c06f6e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:31.373548 [ 3500 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {406808e3-2a20-42a6-8721-3119debca6ac::202506_1_36_7}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c14c18 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c06f6e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:31.396325 [ 5978 ] {30f21f4c-9873-49c1-ac89-352495dd6106} executeQuery: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 7, line 11) (in query: SELECT * FROM urlCluster('test_cluster_two_shards_localhost', 'http://localhost:8123/', LineAsString, headers('cAsE_INSENSITIVE_header' = 'value'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028986fef 6. ./build_docker/./src/Storages/StorageURLCluster.cpp:58: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003080a7af 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, std::allocator, 0>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d32c5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d30ce 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d543e 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 12. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:31.433618 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028986fef 6. ./build_docker/./src/Storages/StorageURLCluster.cpp:58: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003080a7af 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, std::allocator, 0>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d32c5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d30ce 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d543e 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 12. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:31.437702 [ 3931 ] {69e215e2-797f-44ec-a790-a24416af891b} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 2, should be 1: In scope SELECT SHA224(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 104, line 104) (in query: SELECT SHA224(NULL, NULL);) 2025.06.13 15:37:31.453205 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 2, should be 1: In scope SELECT SHA224(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:31.604320 [ 5978 ] {41c3ea7b-0cc0-4911-92fa-057bace463cb} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 8, line 12) (in query: SELECT * FROM urlCluster('test_cluster_two_shards_localhost', 'http://localhost:8123/', LineAsString, headers('bad_header_name: test\nexact_header' = 'value'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/StorageURLCluster.cpp:58: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003080a7af 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, std::allocator, 0>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d32c5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d30ce 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d543e 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 12. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:31.608456 [ 3931 ] {73fb9ed8-9ce9-44a0-83db-6bcdb9784c0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 2, should be 1: In scope SELECT SHA256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 105, line 105) (in query: SELECT SHA256(NULL, NULL);) 2025.06.13 15:37:31.632748 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/StorageURLCluster.cpp:58: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003080a7af 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, std::allocator, 0>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d32c5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d30ce 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d543e 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 12. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:31.633668 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 2, should be 1: In scope SELECT SHA256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:31.750255 [ 3931 ] {3dd48263-3fc2-43b9-a62d-82ce4442c785} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 2, should be 1: In scope SELECT SHA384(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 106, line 106) (in query: SELECT SHA384(NULL, NULL);) 2025.06.13 15:37:31.786016 [ 5978 ] {4f3282fd-4f69-4360-b734-b4dbc6848814} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 9, line 13) (in query: SELECT * FROM urlCluster('test_cluster_two_shards_localhost', 'http://localhost:8123/', LineAsString, headers('bad_header_value' = 'test\nexact_header: value'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/StorageURLCluster.cpp:58: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003080a7af 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, std::allocator, 0>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d32c5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d30ce 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d543e 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 12. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:31.793593 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 2, should be 1: In scope SELECT SHA384(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:31.817873 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/StorageURLCluster.cpp:58: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x000000003080a7af 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, std::allocator, 0>(std::allocator, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d32c5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x00000000284d30ce 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284d543e 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 12. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:31.966077 [ 3931 ] {edaeb293-1eca-467e-bf9f-372c20af44c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 2, should be 1: In scope SELECT SHA512(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 107, line 107) (in query: SELECT SHA512(NULL, NULL);) 2025.06.13 15:37:31.982699 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 2, should be 1: In scope SELECT SHA512(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:32.157353 [ 3931 ] {f28742c1-11aa-4520-aacd-fba9fffdfd71} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 2, should be 1: In scope SELECT SHA512_256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 108, line 108) (in query: SELECT SHA512_256(NULL, NULL);) 2025.06.13 15:37:32.176573 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 2, should be 1: In scope SELECT SHA512_256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:32.640737 [ 3931 ] {316a0b5a-a22b-4550-bf4f-5514f6475f52} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 110, line 110) (in query: SELECT STDDEV_POP(NULL, NULL);) 2025.06.13 15:37:32.656003 [ 3931 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) 2025.06.13 15:37:32.780837 [ 5978 ] {c2c2acc1-834b-43fc-8cf8-f56e0b62a9c8} executeQuery: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 11, line 16) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('exact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:24: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028987121 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:138: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool, bool, std::optional) @ 0x000000002b51f652 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x000000002859629a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595de7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595bdb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285458bd 12. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:125: DB::TableFunctionObjectStorageClusterFallback>::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285de109 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 14. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:32.838471 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:24: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028987121 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:138: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool, bool, std::optional) @ 0x000000002b51f652 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x000000002859629a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595de7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595bdb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285458bd 12. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:125: DB::TableFunctionObjectStorageClusterFallback>::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285de109 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 14. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:33.007592 [ 5978 ] {de8f00c3-3101-485f-ba9b-812a61ff3513} executeQuery: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 12, line 17) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('cAsE_INSENSITIVE_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028986fef 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:138: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool, bool, std::optional) @ 0x000000002b51f652 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x000000002859629a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595de7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595bdb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285458bd 12. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:125: DB::TableFunctionObjectStorageClusterFallback>::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285de109 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 14. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:33.018821 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028986fef 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:138: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool, bool, std::optional) @ 0x000000002b51f652 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x000000002859629a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595de7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595bdb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285458bd 12. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:125: DB::TableFunctionObjectStorageClusterFallback>::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285de109 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 14. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:33.093754 [ 3931 ] {28aae26f-c9ae-4bd8-8027-477e08436e56} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT SUBSTRING_INDEX(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 112, line 112) (in query: SELECT SUBSTRING_INDEX(NULL, NULL);) 2025.06.13 15:37:33.108658 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT SUBSTRING_INDEX(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:33.317283 [ 5978 ] {cc34fa16-6027-43bf-9d8a-a4ed8b53e863} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 13, line 18) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('bad_header_name: test\nexact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:138: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool, bool, std::optional) @ 0x000000002b51f652 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x000000002859629a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595de7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595bdb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285458bd 12. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:125: DB::TableFunctionObjectStorageClusterFallback>::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285de109 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 14. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:33.330764 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:138: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool, bool, std::optional) @ 0x000000002b51f652 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x000000002859629a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595de7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595bdb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285458bd 12. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:125: DB::TableFunctionObjectStorageClusterFallback>::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285de109 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 14. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:33.689671 [ 5163 ] {15072433-9180-44e2-8655-ded3b58eeb28} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(nan). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dccedca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:33.704843 [ 5978 ] {6883960d-b0e1-44db-b57e-488b313d1cbb} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 14, line 19) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('bad_header_value' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:138: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool, bool, std::optional) @ 0x000000002b51f652 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x000000002859629a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595de7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595bdb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285458bd 12. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:125: DB::TableFunctionObjectStorageClusterFallback>::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285de109 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 14. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:33.720213 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dccedca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:33.736013 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:138: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool, bool, std::optional) @ 0x000000002b51f652 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x000000002859629a 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595de7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595bdb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285458bd 12. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:125: DB::TableFunctionObjectStorageClusterFallback>::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285de109 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 14. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:33.786399 [ 3931 ] {525610ae-7056-43f8-9e19-b9bfb755126d} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT TO_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 115, line 115) (in query: SELECT TO_BASE64(NULL, NULL);) 2025.06.13 15:37:33.804901 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT TO_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:33.908566 [ 5163 ] {f07a3820-8ad9-455b-8b48-505d4ce410b9} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(inf). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dccedca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:33.923706 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dccedca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:34.149718 [ 5163 ] {ec3acf96-57bc-4351-b385-5b1e32de72f3} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(-inf). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59906) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dccedca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:34.162965 [ 5163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dccedca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:37:34.439684 [ 5978 ] {f0a7295b-8fa4-4607-9379-bcf9f7b6552a} executeQuery: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: while reading 4: While executing S3(_table_function.s3)Source. (S3_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 15, line 20) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('random_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/IO/S3Common.h:34: DB::S3Exception::S3Exception(Aws::S3::S3Errors, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000002b83337a 5. ./build_docker/./src/IO/S3/getObjectInfo.cpp:88: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, bool, bool) @ 0x000000002b83279b 6. ./build_docker/./src/Disks/ObjectStorages/S3/S3ObjectStorage.cpp:364: DB::S3ObjectStorage::getObjectMetadata(String const&) const @ 0x000000002b827e0e 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:903: DB::StorageObjectStorageSource::KeysIterator::next(unsigned long) @ 0x000000002b5b803d 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:435: DB::StorageObjectStorageSource::createReader(unsigned long, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ReadFromFormatInfo&, std::optional const&, std::shared_ptr const&, std::shared_ptr const&, DB::SchemaCache*, std::shared_ptr const&, unsigned long, unsigned long, bool) @ 0x000000002b5ac960 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:399: DB::StorageObjectStorageSource::createReader() @ 0x000000002b5a920a 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:244: DB::StorageObjectStorageSource::lazyInitialize() @ 0x000000002b5a8e4b 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:253: DB::StorageObjectStorageSource::generate() @ 0x000000002b5a9ad2 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:37:34.447117 [ 5978 ] {} TCPHandler: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: while reading 4: While executing S3(_table_function.s3)Source. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/IO/S3Common.h:34: DB::S3Exception::S3Exception(Aws::S3::S3Errors, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000002b83337a 5. ./build_docker/./src/IO/S3/getObjectInfo.cpp:88: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, bool, bool) @ 0x000000002b83279b 6. ./build_docker/./src/Disks/ObjectStorages/S3/S3ObjectStorage.cpp:364: DB::S3ObjectStorage::getObjectMetadata(String const&) const @ 0x000000002b827e0e 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:903: DB::StorageObjectStorageSource::KeysIterator::next(unsigned long) @ 0x000000002b5b803d 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:435: DB::StorageObjectStorageSource::createReader(unsigned long, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ReadFromFormatInfo&, std::optional const&, std::shared_ptr const&, std::shared_ptr const&, DB::SchemaCache*, std::shared_ptr const&, unsigned long, unsigned long, bool) @ 0x000000002b5ac960 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:399: DB::StorageObjectStorageSource::createReader() @ 0x000000002b5a920a 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:244: DB::StorageObjectStorageSource::lazyInitialize() @ 0x000000002b5a8e4b 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:253: DB::StorageObjectStorageSource::generate() @ 0x000000002b5a9ad2 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:34.500638 [ 6621 ] {9eef69a1-a80a-48a9-a3ea-f3d44625dcf2} ExternalDictionariesLoader: Could not load external dictionary '03f22094-e7a0-45b0-bf9f-da4f307235ac', next update is scheduled at 2025-06-13 15:37:40: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./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:ne190107] (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) @ 0x00000000289721a2 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acdb01b 7. ./build_docker/./src/Dictionaries/DictionarySourceFactory.cpp:102: DB::DictionarySourceFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, DB::DictionaryStructure const&, std::shared_ptr, String const&, bool) const @ 0x000000002acda6b9 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acd6ae9 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbe1603 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dbf4bfc 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbf2a7f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dbf97d1 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x000000002dbf3e43 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x000000002dbf0f40 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000002dc0e135 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x000000002dc0dedf 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:604: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x000000002dbeb700 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x000000002dbeba6d 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x000000002dbe222a 11. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000017f46bf3 12. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f42c84 13. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f7d235 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 32. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 33. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 34. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 35. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 36. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 37. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 38. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 39. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 40. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 41. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 42. ? @ 0x00007f2f4224dac3 43. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:34.547111 [ 3982 ] {9eef69a1-a80a-48a9-a3ea-f3d44625dcf2} 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_ng0jeqv8', '.restricted_dict'), 'value', toUInt64(1)). (DICTIONARY_ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60720) (comment: 01045_dictionaries_restrictions.sql) (query 2, line 11) (in query: SELECT dictGetString(concat('test_ng0jeqv8', '.restricted_dict'), 'value', toUInt64(1))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./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:ne190107] (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) @ 0x00000000289721a2 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acdb01b 7. ./build_docker/./src/Dictionaries/DictionarySourceFactory.cpp:102: DB::DictionarySourceFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, DB::DictionaryStructure const&, std::shared_ptr, String const&, bool) const @ 0x000000002acda6b9 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acd6ae9 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbe1603 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dbf4bfc 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbf2a7f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dbf97d1 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:37:34.553888 [ 3982 ] {} 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_ng0jeqv8', '.restricted_dict'), 'value', toUInt64(1)). (DICTIONARY_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./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:ne190107] (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) @ 0x00000000289721a2 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002acdb01b 7. ./build_docker/./src/Dictionaries/DictionarySourceFactory.cpp:102: DB::DictionarySourceFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, DB::DictionaryStructure const&, std::shared_ptr, String const&, bool) const @ 0x000000002acda6b9 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:47: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002acd6ae9 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000002dbe1603 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1043: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002dbf4bfc 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002dbf2a7f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000002dbf97d1 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x000000002dbf3e43 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x000000002dbf0f40 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000002dc0e135 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x000000002dc0dedf 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:604: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x000000002dbeb700 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1368: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x000000002dbeba6d 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x000000002dbe222a 11. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000017f46bf3 12. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f42c84 13. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f7d235 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 32. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 33. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 34. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 35. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 36. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 37. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 38. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 39. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 40. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 41. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 42. ? @ 0x00007f2f4224dac3 43. ? @ 0x00007f2f422df850 2025.06.13 15:37:34.593968 [ 6193 ] {bed32d28-4dee-46f9-b31c-92890b1d9106} executeQuery: Code: 36. DB::Exception: Argument 'kafka_broker_list' must be a literal, get Function_equals (value: a = '1'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60742) (comment: 03305_fix_kafka_table_with_kw_arguments.sql) (query 1, line 3) (in query: CREATE TABLE default.test ( `id` UInt32, `message` String ) ENGINE = Kafka(a = '1', 'clickhouse');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000284c482f 5. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:25: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000030843d0a 6. ./build_docker/./src/Storages/Kafka/StorageKafkaUtils.cpp:169: DB::registerStorageKafka(DB::StorageFactory&)::$_0::operator()(DB::StorageFactory::Arguments const&) const @ 0x000000002b5114ef 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:34.600955 [ 6193 ] {} TCPHandler: Code: 36. DB::Exception: Argument 'kafka_broker_list' must be a literal, get Function_equals (value: a = '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x00000000284c482f 5. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:25: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000030843d0a 6. ./build_docker/./src/Storages/Kafka/StorageKafkaUtils.cpp:169: DB::registerStorageKafka(DB::StorageFactory&)::$_0::operator()(DB::StorageFactory::Arguments const&) const @ 0x000000002b5114ef 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:34.829139 [ 4930 ] {0cdbc4bf-382e-45c2-b86b-c3759b3bf18c} executeQuery: Code: 475. DB::Exception: ORDER BY containing the same expression with and without WITH FILL modifier is not supported. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60748) (comment: 03015_with_fill_invalid_expression.sql) (query 1, line 1) (in query: select number as x, number + 1 as y from numbers(5) where number % 3 == 1 order by y, x with fill from 1 to 4, y with fill from 2 to 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:287: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x00000000320f5e7c 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], bool const&, std::allocator, 0>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x00000000320f08e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x00000000320f0714 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x00000000320ef6dd 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c36b57b 10. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002c36b2e5 11. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000320ee832 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000032115740 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:34.854800 [ 4930 ] {} TCPHandler: Code: 475. DB::Exception: ORDER BY containing the same expression with and without WITH FILL modifier is not supported. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:287: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x00000000320f5e7c 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], bool const&, std::allocator, 0>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x00000000320f08e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x00000000320f0714 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x00000000320ef6dd 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c36b57b 10. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002c36b2e5 11. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000320ee832 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000032115740 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:34.863492 [ 5978 ] {4215b99c-818e-4c04-899c-6bfa156d0479} executeQuery: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 16, line 22) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('exact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:24: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028987121 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:90: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, std::shared_ptr) @ 0x000000002b53b7fe 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorageCluster* std::construct_at[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, DB::StorageObjectStorageCluster*>(DB::StorageObjectStorageCluster*, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3c82 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, std::allocator, 0>(std::allocator, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3a00 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c37f4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285c2322 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:34.880872 [ 3982 ] {e3e3d04f-872f-4fcf-9eee-69845ef87b83} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60720) (comment: 01045_dictionaries_restrictions.sql) (query 4, line 16) (in query: DROP DICTIONARY IF EXISTS test_ng0jeqv8.restricted_dict), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:37:34.909218 [ 3982 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:37:34.941439 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:24: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028987121 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:90: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, std::shared_ptr) @ 0x000000002b53b7fe 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorageCluster* std::construct_at[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, DB::StorageObjectStorageCluster*>(DB::StorageObjectStorageCluster*, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3c82 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, std::allocator, 0>(std::allocator, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3a00 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c37f4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285c2322 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:34.980306 [ 3931 ] {7463532f-aea2-4478-8dde-fc0d5f7260cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 120, line 120) (in query: SELECT URLHierarchy(NULL, NULL);) 2025.06.13 15:37:35.054122 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:35.187268 [ 3931 ] {756f312e-bcc0-4906-93c6-fd22dd3195cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 121, line 121) (in query: SELECT URLPathHierarchy(NULL, NULL);) 2025.06.13 15:37:35.214150 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:35.340319 [ 5978 ] {9f14f904-cc7a-4e89-a09f-2ab5c55b6d06} executeQuery: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 17, line 23) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('cAsE_INSENSITIVE_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028986fef 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:90: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, std::shared_ptr) @ 0x000000002b53b7fe 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorageCluster* std::construct_at[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, DB::StorageObjectStorageCluster*>(DB::StorageObjectStorageCluster*, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3c82 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, std::allocator, 0>(std::allocator, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3a00 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c37f4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285c2322 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:35.350359 [ 3931 ] {a0b7020c-06da-41b5-bfb9-894cd3a61af6} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTCTimestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 122, line 122) (in query: SELECT UTCTimestamp(NULL, NULL);) 2025.06.13 15:37:35.356671 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:29: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x0000000028986fef 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:90: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, std::shared_ptr) @ 0x000000002b53b7fe 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorageCluster* std::construct_at[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, DB::StorageObjectStorageCluster*>(DB::StorageObjectStorageCluster*, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3c82 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, std::allocator, 0>(std::allocator, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3a00 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c37f4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285c2322 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:35.365023 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTCTimestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:35.528361 [ 3931 ] {b6143321-72a3-4819-9f21-9d61a981c57d} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTC_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 123, line 123) (in query: SELECT UTC_timestamp(NULL, NULL);) 2025.06.13 15:37:35.539463 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTC_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:35.693731 [ 5978 ] {89ae490f-b535-484f-8b61-c2507af5f7f0} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 18, line 24) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('bad_header_name: test\nexact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:90: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, std::shared_ptr) @ 0x000000002b53b7fe 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorageCluster* std::construct_at[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, DB::StorageObjectStorageCluster*>(DB::StorageObjectStorageCluster*, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3c82 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, std::allocator, 0>(std::allocator, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3a00 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c37f4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285c2322 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:35.704705 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:90: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, std::shared_ptr) @ 0x000000002b53b7fe 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorageCluster* std::construct_at[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, DB::StorageObjectStorageCluster*>(DB::StorageObjectStorageCluster*, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3c82 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, std::allocator, 0>(std::allocator, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3a00 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c37f4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285c2322 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:35.743164 [ 6957 ] {} ExternalDictionariesLoader: Could not update external dictionary '61e0d5b5-88ca-4299-b8ed-7f0a0cbb8581', leaving the previous version, next update is scheduled at 2025-06-13 15:37:40: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f585dc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f5af07 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f54898 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f54302 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dd53bf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dcd2b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 30. DB::FlatDictionary::loadData() @ 0x0000000028a43c8b 31. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000028a434fb (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:36.085164 [ 5978 ] {e6ddea42-aedc-4fda-b180-6487d165c608} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 19, line 25) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('bad_header_value' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:90: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, std::shared_ptr) @ 0x000000002b53b7fe 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorageCluster* std::construct_at[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, DB::StorageObjectStorageCluster*>(DB::StorageObjectStorageCluster*, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3c82 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, std::allocator, 0>(std::allocator, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3a00 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c37f4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285c2322 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:36.109326 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:21: DB::HTTPHeaderFilter::checkHeaders(std::vector> const&) const @ 0x00000000289870a5 6. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::check(std::shared_ptr) const @ 0x000000002b628ef2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:90: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, std::shared_ptr) @ 0x000000002b53b7fe 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorageCluster* std::construct_at[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, DB::StorageObjectStorageCluster*>(DB::StorageObjectStorageCluster*, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3c82 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, std::allocator, 0>(std::allocator, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c3a00 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, std::nullptr_t, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, std::nullptr_t&&) @ 0x00000000285c37f4 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285c2322 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 13. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:36.724649 [ 8101 ] {3da3fc98-813d-4fba-b713-f0e7cb2f920e} executeQuery: Code: 36. DB::Exception: Columns: a listed both in columns to sum and in partition key. That is not allowed. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60842) (comment: 01373_summing_merge_tree_explicit_columns_definition.sql) (query 2, line 3) (in query: CREATE TABLE tt_error_1373 (`a` Int64, `d` Int64, `val` Int64) ENGINE = SummingMergeTree((a, val)) PARTITION BY a ORDER BY d SETTINGS index_granularity = 50691, min_bytes_for_wide_part = 391958119, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 248715976, compact_parts_max_granules_to_buffer = 101, compact_parts_merge_max_bytes_to_prefetch_part = 21611028, merge_max_block_size = 23753, old_parts_lifetime = 436., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 23, min_merge_bytes_to_use_direct_io = 7507812585, index_granularity_bytes = 18927280, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 3, 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 = 82788, primary_key_compress_block_size = 55275, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1232: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c728d7 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:36.744348 [ 8101 ] {} TCPHandler: Code: 36. DB::Exception: Columns: a listed both in columns to sum and in partition key. That is not allowed. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1232: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c728d7 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:36.893879 [ 7755 ] {3b7f3c90-ff33-413f-a5df-06eda54ec317} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAny('123', ['12']). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 5, line 9) (in query: select multiMatchAny('123', ['12']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0f85c5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:36.911685 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAny('123', ['12']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0f85c5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:37.140127 [ 7279 ] {} virtual DB::AutoFinalizedWriteBuffer::~AutoFinalizedWriteBuffer() [Base = DB::WriteBufferFromPocoSocket]: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:49050). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/IO/WriteBuffer.cpp:95: DB::WriteBuffer::finalize() @ 0x0000000023b66a57 7. ./src/IO/AutoFinalizedWriteBuffer.h:25: DB::AutoFinalizedWriteBuffer::~AutoFinalizedWriteBuffer() @ 0x00000000316f3564 8. std::__shared_weak_count::__release_shared[abi:ne190107]() @ 0x0000000017cbe79e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:668: DB::HTTPServerResponse::~HTTPServerResponse() @ 0x00000000316eb0ef 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:91: DB::HTTPServerConnection::run() @ 0x00000000316e8c90 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:37.222548 [ 7755 ] {2d5e356a-f736-4d3c-b266-1fdda3ffaf0a} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAny('123', ['1', '2']). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 6, line 10) (in query: select multiMatchAny('123', ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0f85c5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:37.234770 [ 6219 ] {f482d59f-2ad5-4fe7-b884-eb3b5bf24d6e} executeQuery: Code: 264. DB::Exception: Table test_5z9o57xf.t2 (4a8ddbf6-b602-4230-9a58-58daa49d577e) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60830) (comment: 00118_storage_join.sql) (query 4, line 6) (in query: SELECT k, s FROM (SELECT number AS k FROM system.numbers LIMIT 10) js1 ANY LEFT JOIN t2 USING k ORDER BY k;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/StorageJoin.cpp:248: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x000000003043bffb 6. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf3bd0 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213d4c9 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:37:37.237793 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAny('123', ['1', '2']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0f85c5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:37.251893 [ 6219 ] {} TCPHandler: Code: 264. DB::Exception: Table test_5z9o57xf.t2 (4a8ddbf6-b602-4230-9a58-58daa49d577e) 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/StorageJoin.cpp:248: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x000000003043bffb 6. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf3bd0 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213d4c9 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:37:37.531384 [ 5978 ] {3c24f775-e945-4d55-add0-d27a016a7400} executeQuery: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: while reading 4: While executing Remote. (S3_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 02752_forbidden_headers.sql) (query 20, line 26) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('random_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/IO/S3Common.h:34: DB::S3Exception::S3Exception(Aws::S3::S3Errors, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000002b83337a 5. ./build_docker/./src/IO/S3/getObjectInfo.cpp:88: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, bool, bool) @ 0x000000002b83279b 6. ./build_docker/./src/Disks/ObjectStorages/S3/S3ObjectStorage.cpp:364: DB::S3ObjectStorage::getObjectMetadata(String const&) const @ 0x000000002b827e0e 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:903: DB::StorageObjectStorageSource::KeysIterator::next(unsigned long) @ 0x000000002b5b803d 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageStableTaskDistributor.cpp:114: DB::StorageObjectStorageStableTaskDistributor::getMatchingFileFromIterator(unsigned long) @ 0x000000002b611ef1 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageStableTaskDistributor.cpp:32: DB::StorageObjectStorageStableTaskDistributor::getNextTask(unsigned long) @ 0x000000002b610cac 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:393: String std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, std::shared_ptr) const::$_0, String (unsigned long)>>(std::__function::__policy_storage const*, unsigned long) @ 0x000000002b5432cc 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3b9f30 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:647: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x000000002c3b67df 13. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:586: DB::RemoteQueryExecutor::readAsync() @ 0x000000002c3b8e99 14. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:182: DB::RemoteSource::tryGenerate() @ 0x0000000031f4ee80 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:37.573253 [ 5978 ] {} TCPHandler: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: while reading 4: While executing Remote. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/IO/S3Common.h:34: DB::S3Exception::S3Exception(Aws::S3::S3Errors, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000002b83337a 5. ./build_docker/./src/IO/S3/getObjectInfo.cpp:88: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, bool, bool) @ 0x000000002b83279b 6. ./build_docker/./src/Disks/ObjectStorages/S3/S3ObjectStorage.cpp:364: DB::S3ObjectStorage::getObjectMetadata(String const&) const @ 0x000000002b827e0e 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:903: DB::StorageObjectStorageSource::KeysIterator::next(unsigned long) @ 0x000000002b5b803d 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageStableTaskDistributor.cpp:114: DB::StorageObjectStorageStableTaskDistributor::getMatchingFileFromIterator(unsigned long) @ 0x000000002b611ef1 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageStableTaskDistributor.cpp:32: DB::StorageObjectStorageStableTaskDistributor::getNextTask(unsigned long) @ 0x000000002b610cac 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:393: String std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, std::shared_ptr) const::$_0, String (unsigned long)>>(std::__function::__policy_storage const*, unsigned long) @ 0x000000002b5432cc 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3b9f30 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:647: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x000000002c3b67df 13. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:586: DB::RemoteQueryExecutor::readAsync() @ 0x000000002c3b8e99 14. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:182: DB::RemoteSource::tryGenerate() @ 0x0000000031f4ee80 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:37.617158 [ 6219 ] {96012318-f03b-4413-b350-b079f41b5f10} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41440) (comment: 00118_storage_join.sql) (in query: DROP DATABASE IF EXISTS test_5z9o57xf SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:37.629046 [ 6219 ] {96012318-f03b-4413-b350-b079f41b5f10} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:37.717917 [ 4172 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:52040, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:37.721908 [ 4172 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:52040, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:37.806806 [ 7755 ] {89aedb67-a94f-42a4-b3bd-1dec324a8bf5} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAnyIndex('123', ['12']). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 8, line 13) (in query: select multiMatchAnyIndex('123', ['12']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f01a805 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:37.837781 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAnyIndex('123', ['12']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f01a805 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:38.027110 [ 7755 ] {3ed2e307-ecb7-40c1-aeb2-8706f0515a41} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAnyIndex('123', ['1', '2']). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 9, line 14) (in query: select multiMatchAnyIndex('123', ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f01a805 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:38.037249 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAnyIndex('123', ['1', '2']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f01a805 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:38.057160 [ 3931 ] {e2462303-5f19-45f5-95aa-b7da7cc8b670} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=812, jobs=784). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 134, line 134) (in query: SELECT YYYYMMDDhhmmssToDateTime64(NULL, NULL);) 2025.06.13 15:37:38.165836 [ 3931 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=812, jobs=784). (CANNOT_SCHEDULE_TASK) 2025.06.13 15:37:38.447751 [ 3931 ] {b4768ae8-d3d5-4912-83c5-4bf980daaeae} executeQuery: Code: 43. DB::Exception: Second argument to _CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT _CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 135, line 135) (in query: SELECT _CAST(NULL, NULL);) 2025.06.13 15:37:38.487054 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to _CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT _CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:37:38.666297 [ 3931 ] {3fb792a2-2aad-4f32-a05c-bc962836e348} executeQuery: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly: In scope SELECT __actionName(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 136, line 136) (in query: SELECT __actionName(NULL, NULL);) 2025.06.13 15:37:38.703425 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly: In scope SELECT __actionName(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:37:39.024852 [ 7755 ] {bdaa8208-b567-4ceb-b9c5-a9652bbf1b8e} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAllIndices('123', ['12']). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 11, line 17) (in query: select multiMatchAllIndices('123', ['12']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0153b5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:39.077811 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAllIndices('123', ['12']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0153b5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:39.238839 [ 3931 ] {92499de1-5c9e-42c9-8a8c-e6bf47480d6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 2, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 139, line 139) (in query: SELECT __bitSwapLastTwo(NULL, NULL);) 2025.06.13 15:37:39.256232 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 2, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:39.256931 [ 7755 ] {71e73d86-5ade-4387-a337-c63ec6edefd2} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAllIndices('123', ['1', '2']). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 12, line 18) (in query: select multiMatchAllIndices('123', ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0153b5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:39.271537 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAllIndices('123', ['1', '2']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0153b5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:39.453528 [ 3931 ] {1ee32dd1-2c47-4742-bd3b-af820511e696} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 2, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 140, line 140) (in query: SELECT __bitWrapperFunc(NULL, NULL);) 2025.06.13 15:37:39.471747 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 2, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:39.576352 [ 3931 ] {4163b8cd-74cb-4f37-b816-917bf95947b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 2, should be 1: In scope SELECT __getScalar(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 141, line 141) (in query: SELECT __getScalar(NULL, NULL);) 2025.06.13 15:37:39.590394 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 2, should be 1: In scope SELECT __getScalar(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:39.710656 [ 3931 ] {fb4ca2e1-51a8-456d-8e22-5fde29ae06d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 2, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 142, line 142) (in query: SELECT __scalarSubqueryResult(NULL, NULL);) 2025.06.13 15:37:39.726009 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 2, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:39.783924 [ 3931 ] {09ff1d73-acec-40fc-a836-99f3f58ffb4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 2, should be 1: In scope SELECT abs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 143, line 143) (in query: SELECT abs(NULL, NULL);) 2025.06.13 15:37:39.784850 [ 7755 ] {3fd46b3c-697a-42fd-8b12-9e9894347b53} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAny('123', 0, ['12']). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 14, line 21) (in query: select multiFuzzyMatchAny('123', 0, ['12']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00bd25 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:39.798015 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 2, should be 1: In scope SELECT abs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:39.815018 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAny('123', 0, ['12']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00bd25 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:39.888319 [ 3931 ] {cfff14fb-c0d4-42e7-86e0-cb24b7d432fc} executeQuery: Code: 43. DB::Exception: Second argument to accurateCast must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCast(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 144, line 144) (in query: SELECT accurateCast(NULL, NULL);) 2025.06.13 15:37:39.909742 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCast must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCast(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:37:40.095116 [ 7755 ] {a242c360-fb2f-4f80-aeb5-f59c22210c41} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAny('123', 0, ['1', '2']). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 15, line 22) (in query: select multiFuzzyMatchAny('123', 0, ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00bd25 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:40.113783 [ 3931 ] {2599dd03-b080-425f-afb7-16c7def430b4} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 145, line 145) (in query: SELECT accurateCastOrDefault(NULL, NULL);) 2025.06.13 15:37:40.118166 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAny('123', 0, ['1', '2']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00bd25 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:40.132718 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:37:40.252373 [ 3931 ] {3c4c7cae-4294-4ea6-9c36-47c839fc365c} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrNull must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCastOrNull(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 146, line 146) (in query: SELECT accurateCastOrNull(NULL, NULL);) 2025.06.13 15:37:40.272201 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrNull must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCastOrNull(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:37:40.461147 [ 3931 ] {1fdf4aba-39a5-4652-874a-948ad15e27d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 2, should be 1: In scope SELECT acos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 147, line 147) (in query: SELECT acos(NULL, NULL);) 2025.06.13 15:37:40.480529 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 2, should be 1: In scope SELECT acos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:40.587306 [ 7755 ] {5569ce35-4b4a-4645-a092-df14e62132df} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAnyIndex('123', 0, ['12']). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 17, line 25) (in query: select multiFuzzyMatchAnyIndex('123', 0, ['12']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0117a5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:40.641839 [ 3931 ] {19b482cb-0b6e-417f-8472-1e89d76fd774} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 2, should be 1: In scope SELECT acosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 148, line 148) (in query: SELECT acosh(NULL, NULL);) 2025.06.13 15:37:40.642170 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAnyIndex('123', 0, ['12']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0117a5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:40.660424 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 2, should be 1: In scope SELECT acosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:40.882019 [ 7755 ] {6fd74499-05b9-41d7-8c04-f85276c62109} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAnyIndex('123', 0, ['1', '2']). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 18, line 26) (in query: select multiFuzzyMatchAnyIndex('123', 0, ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0117a5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:40.895166 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAnyIndex('123', 0, ['1', '2']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0117a5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:41.562406 [ 7755 ] {4317c850-a723-4b0f-978a-6b2759f68545} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAllIndices('123', 0, ['12']). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 20, line 29) (in query: select multiFuzzyMatchAllIndices('123', 0, ['12']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f002fe5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:41.626211 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAllIndices('123', 0, ['12']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f002fe5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:41.784068 [ 7755 ] {e6becb90-91d4-4959-8305-852f9616001c} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAllIndices('123', 0, ['1', '2']). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 21, line 30) (in query: select multiFuzzyMatchAllIndices('123', 0, ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f002fe5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:41.818269 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAllIndices('123', 0, ['1', '2']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f002fe5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:37:42.424985 [ 7755 ] {1bca07f4-0d8b-478c-a994-21827afe385a} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAny(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAny(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt8 : 2'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 24, line 35) (in query: select multiMatchAny(materialize('123'), materialize(['12']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0f85c5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:42.462094 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAny(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAny(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt8 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0f85c5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:42.558080 [ 3510 ] {8ccf290b-5945-45b4-b8fa-eea2a065640f::all_33_57_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030c4f297 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3acd74 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 13. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1afd8 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 16. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:42.564240 [ 3498 ] {8ccf290b-5945-45b4-b8fa-eea2a065640f::all_84_89_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:42.570953 [ 3512 ] {8ccf290b-5945-45b4-b8fa-eea2a065640f::all_79_83_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030c4f297 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3acd74 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 13. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1afd8 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 16. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:42.571078 [ 3502 ] {8ccf290b-5945-45b4-b8fa-eea2a065640f::all_74_78_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:42.630164 [ 3504 ] {8ccf290b-5945-45b4-b8fa-eea2a065640f::all_1_32_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030c4f297 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3acd74 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 13. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1afd8 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 16. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:42.668150 [ 7755 ] {8b50f761-3242-4d31-97a4-7ff3cee0c8c3} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAny(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAny(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt8 : 2'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 25, line 36) (in query: select multiMatchAny(materialize('123'), materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0f85c5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:42.699651 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAny(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAny(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt8 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0f85c5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:43.092591 [ 7755 ] {f2343dd6-7e10-4771-8fe0-52f797ff4afc} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAnyIndex(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAnyIndex(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt64 : 2'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 27, line 39) (in query: select multiMatchAnyIndex(materialize('123'), materialize(['12']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f01a805 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:43.101874 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAnyIndex(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAnyIndex(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f01a805 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:43.387536 [ 7755 ] {61009537-09b3-49fe-9ad3-068e1266a0ca} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAnyIndex(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAnyIndex(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt64 : 2'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 28, line 40) (in query: select multiMatchAnyIndex(materialize('123'), materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f01a805 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:43.394039 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAnyIndex(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAnyIndex(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f01a805 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:43.556978 [ 3931 ] {54905176-6496-43c6-bcc1-c99fd670b5f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 2, should be 1: In scope SELECT addressToLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 163, line 163) (in query: SELECT addressToLine(NULL, NULL);) 2025.06.13 15:37:43.581041 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 2, should be 1: In scope SELECT addressToLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:43.705592 [ 3931 ] {24a2d68f-f065-459c-b2b7-2caf5c0e0538} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 2, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 164, line 164) (in query: SELECT addressToLineWithInlines(NULL, NULL);) 2025.06.13 15:37:43.714754 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 2, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:43.807383 [ 3931 ] {a9c9000f-c954-47f1-93d8-ca69e4949661} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 2, should be 1: In scope SELECT addressToSymbol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 165, line 165) (in query: SELECT addressToSymbol(NULL, NULL);) 2025.06.13 15:37:43.839871 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 2, should be 1: In scope SELECT addressToSymbol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:43.900139 [ 7755 ] {75489b0a-49a5-49ac-80c2-cd2f1cd4d0a7} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAllIndices(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAllIndices(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) Array(UInt64) : 2'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 30, line 43) (in query: select multiMatchAllIndices(materialize('123'), materialize(['12']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0153b5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:43.913753 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAllIndices(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAllIndices(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) Array(UInt64) : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0153b5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:44.134886 [ 7755 ] {9a5adf1d-c076-494e-8498-dbac3bf88d56} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAllIndices(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAllIndices(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) Array(UInt64) : 2'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 31, line 44) (in query: select multiMatchAllIndices(materialize('123'), materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0153b5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:44.149006 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAllIndices(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAllIndices(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) Array(UInt64) : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0153b5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:44.366287 [ 8101 ] {8f1a35b9-a325-4d3a-b5f3-38c17d176740} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 25.67 MiB (attempt to allocate chunk of 1.22 MiB), maximum: 9.31 GiB: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60870) (comment: 02493_max_streams_for_merge_tree_reading.sql) (query 4, line 7) (in query: insert into t select number from numbers_mt(10000000) settings max_insert_threads=8;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc3b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffa4627 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x000000003224ef9c 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:37:44.489091 [ 8101 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 25.67 MiB (attempt to allocate chunk of 1.22 MiB), maximum: 9.31 GiB: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc3b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffa4627 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x000000003224ef9c 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:37:44.554006 [ 7755 ] {ec9910ce-67a9-4b3f-8783-bf48905d92ae} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAny(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 33, line 47) (in query: select multiFuzzyMatchAny(materialize('123'), 0, materialize(['12']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00bd25 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:44.563525 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAny(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00bd25 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:44.804445 [ 7755 ] {b708b353-8cbd-410b-93fe-1e81c955cd07} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAny(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 34, line 48) (in query: select multiFuzzyMatchAny(materialize('123'), 0, materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00bd25 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:44.819003 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAny(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f00bd25 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:44.933461 [ 5163 ] {6173132b-aca6-40c2-8ac9-9738d2c6a284} executeQuery: Code: 388. DB::Exception: Cannot OPTIMIZE table: There is no need to merge parts according to merge selector algorithm. (CANNOT_ASSIGN_OPTIMIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40098) (comment: 03001_consider_lwd_when_merge.sql) (query 6, line 12) (in query: OPTIMIZE TABLE lwd_merge;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1725: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311eaa86 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:37:44.947648 [ 5163 ] {} TCPHandler: Code: 388. DB::Exception: Cannot OPTIMIZE table: There is no need to merge parts according to merge selector algorithm. (CANNOT_ASSIGN_OPTIMIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1725: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311eaa86 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:37:45.515766 [ 7755 ] {7c4ed7fe-8538-42c5-8d4e-3f7fa3ab09df} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAnyIndex(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAnyIndex(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt64 : 3'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 36, line 51) (in query: select multiFuzzyMatchAnyIndex(materialize('123'), 0, materialize(['12']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0117a5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:45.530687 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAnyIndex(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAnyIndex(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt64 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0117a5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:45.768640 [ 6956 ] {} DDLWorker(rdb_test_15_2): Error on initialization of rdb_test_15_2: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:45.791532 [ 7755 ] {6827026b-47d6-46e0-ad8f-18069cc6efe7} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAnyIndex(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAnyIndex(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt64 : 3'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 37, line 52) (in query: select multiFuzzyMatchAnyIndex(materialize('123'), 0, materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0117a5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:45.798859 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAnyIndex(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAnyIndex(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt64 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0117a5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:46.013091 [ 5163 ] {dc712c9b-8c1f-45cc-b38d-47d8134c4925} executeQuery: Code: 388. DB::Exception: Cannot OPTIMIZE table: There is no need to merge parts according to merge selector algorithm. (CANNOT_ASSIGN_OPTIMIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40098) (comment: 03001_consider_lwd_when_merge.sql) (query 9, line 17) (in query: OPTIMIZE TABLE lwd_merge;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1725: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311eaa86 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:37:46.020511 [ 5163 ] {} TCPHandler: Code: 388. DB::Exception: Cannot OPTIMIZE table: There is no need to merge parts according to merge selector algorithm. (CANNOT_ASSIGN_OPTIMIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1725: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311eaa86 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:37:46.266333 [ 7755 ] {47c044a7-ac06-4829-ba3f-31c2a8773911} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAllIndices(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAllIndices(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) Array(UInt64) : 3'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 39, line 55) (in query: select multiFuzzyMatchAllIndices(materialize('123'), 0, materialize(['12']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f002fe5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:46.275142 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAllIndices(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAllIndices(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) Array(UInt64) : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x00000000247c1eef 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad756be 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f002fe5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:46.566987 [ 7755 ] {9301bd2b-dff7-443f-82b3-bf3b14e15790} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAllIndices(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAllIndices(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) Array(UInt64) : 3'. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60818) (comment: 02004_max_hyperscan_regex_length.sql) (query 40, line 56) (in query: select multiFuzzyMatchAllIndices(materialize('123'), 0, materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f002fe5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:46.584010 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAllIndices(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAllIndices(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) Array(UInt64) : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000018f1332f 5. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002ad75736 6. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f002fe5 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:46.606469 [ 3931 ] {ab7adcf1-3216-4ace-9e9a-1679db0e50c3} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 177, line 177) (in query: SELECT anyLastRespectNulls(NULL, NULL);) 2025.06.13 15:37:46.664686 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:46.737188 [ 3931 ] {76f5f4f0-6a25-4cf3-9534-94a5e200b6d3} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 178, line 178) (in query: SELECT anyLast_respect_nulls(NULL, NULL);) 2025.06.13 15:37:46.760846 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:46.882653 [ 3931 ] {028a60d5-6b11-4d1d-b6bb-9392a504c3d7} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 179, line 179) (in query: SELECT anyRespectNulls(NULL, NULL);) 2025.06.13 15:37:46.941249 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:47.024843 [ 3931 ] {4971498e-4f7c-4876-a33f-3aa3a0797f6a} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 180, line 180) (in query: SELECT anyValueRespectNulls(NULL, NULL);) 2025.06.13 15:37:47.028906 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:47.091535 [ 6954 ] {} DDLWorker(rdb_test_15_3): Error on initialization of rdb_test_15_3: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:47.130310 [ 3931 ] {b33c295f-350e-4fea-bd27-733060b52ca8} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 181, line 181) (in query: SELECT any_respect_nulls(NULL, NULL);) 2025.06.13 15:37:47.138085 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:47.236743 [ 4098 ] {cdaaacd3-009f-46cd-8e0a-9ce882fd5821} executeQuery: Code: 57. DB::Exception: Table test_5.B already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 00927_asof_join_other_types.gen.sql) (in query: /* ddl_entry=query-0000000031 */ CREATE TABLE test_5.B UUID 'e89ab325-1789-4c3c-abb6-954bb1fb574a' (`k` UInt32, `t` DateTime('Asia/Istanbul'), `b` Float64) ENGINE = MergeTree ORDER BY (k, t) SETTINGS index_granularity = 59320, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.05977092310786247, 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 = 35958814, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 24358964, merge_max_block_size = 6759, old_parts_lifetime = 378., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 26387777, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 15377, primary_key_compress_block_size = 36091, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:47.341244 [ 4098 ] {cdaaacd3-009f-46cd-8e0a-9ce882fd5821} executeQuery: Code: 57. DB::Exception: Table test_5.B already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60026) (comment: 00927_asof_join_other_types.gen.sql) (query 53, line 96) (in query: CREATE TABLE B (`k` UInt32, `t` DateTime('Asia/Istanbul'), `b` Float64) ENGINE = MergeTree ORDER BY (k, t) SETTINGS index_granularity = 59320, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.05977092310786247, 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 = 35958814, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 24358964, merge_max_block_size = 6759, old_parts_lifetime = 378., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 26387777, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 15377, primary_key_compress_block_size = 36091, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:47.359256 [ 4098 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.B already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:47.482912 [ 3931 ] {ffbc3c2e-d557-47a3-b53d-52aac96890e1} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 183, line 183) (in query: SELECT any_value_respect_nulls(NULL, NULL);) 2025.06.13 15:37:47.494604 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:47.564902 [ 4171 ] {aa3912d4-e813-4b6a-87b2-5c3d183bd323} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000006 */ ALTER TABLE rdb_test_15.mt (DROP PARTITION ID 'all'), (ADD COLUMN `m` int)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:47.615631 [ 4171 ] {aa3912d4-e813-4b6a-87b2-5c3d183bd323} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40152) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_15.mt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:47.629466 [ 4171 ] {} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:49.037372 [ 6219 ] {9420fa88-f58b-469d-a563-94f5a57bf02e} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000007 */ ALTER TABLE rdb_test_15.rmt (DROP PARTITION ID 'all'), (ADD COLUMN `m` int)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5cb284 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c4049 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:49.178410 [ 6219 ] {9420fa88-f58b-469d-a563-94f5a57bf02e} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40154) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_15.rmt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5cb284 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c4049 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:49.195343 [ 6219 ] {} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5cb284 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c4049 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:49.881466 [ 5005 ] {880a892b-f0b0-4764-8941-b1e92e0d9ce8} 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.20286.altinityantalya (altinity build)) (from [::1]:40192) (comment: 00926_zookeeper_adaptive_index_granularity_replicated_merge_tree_long.sql) (query 4, line 8) (in query: CREATE TABLE zero_rows_per_granule1 ( p Date, k UInt64, v1 UInt64, v2 Int64 ) ENGINE ReplicatedMergeTree('/clickhouse/tables/{database}/test_00926/zero_rows_in_granule', '1') PARTITION BY toYYYYMM(p) ORDER BY k SETTINGS index_granularity_bytes = 20, min_index_granularity_bytes = 10, write_final_mark = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:49.908753 [ 5005 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:50.070205 [ 6234 ] {9464ee5f-4e17-4cdb-b347-888764dc1b47} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000008 */ ALTER TABLE rdb_test_15.mt (DROP PARTITION ID 'all'), (UPDATE n = 2 WHERE 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:50.105141 [ 8431 ] {1d104a05-891d-4afc-b9a0-5dd01c91c5b2} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40236) (comment: 02315_readonly_create_function.sh) (query 1, line 1) (in query: CREATE FUNCTION test_function AS (x) -> x + 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4a216 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd49055 6. ./build_docker/./src/Access/ContextAccess.cpp:775: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002bd58aa2 7. ./build_docker/./src/Access/ContextAccess.cpp:827: bool DB::ContextAccess::checkAccessImpl(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002bd1bb89 8. ./src/Access/ContextAccess.h:261: void DB::Context::checkAccessImpl(DB::AccessRightsElements const&) const @ 0x000000002d4bb5a7 9. ./build_docker/./src/Interpreters/InterpreterCreateFunctionQuery.cpp:46: DB::InterpreterCreateFunctionQuery::execute() @ 0x000000002e3632f1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:50.137636 [ 8431 ] {} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4a216 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd49055 6. ./build_docker/./src/Access/ContextAccess.cpp:775: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002bd58aa2 7. ./build_docker/./src/Access/ContextAccess.cpp:827: bool DB::ContextAccess::checkAccessImpl(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002bd1bb89 8. ./src/Access/ContextAccess.h:261: void DB::Context::checkAccessImpl(DB::AccessRightsElements const&) const @ 0x000000002d4bb5a7 9. ./build_docker/./src/Interpreters/InterpreterCreateFunctionQuery.cpp:46: DB::InterpreterCreateFunctionQuery::execute() @ 0x000000002e3632f1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:50.151357 [ 6234 ] {9464ee5f-4e17-4cdb-b347-888764dc1b47} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40206) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_15.mt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:50.168574 [ 6234 ] {} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:50.500244 [ 4098 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:37:50.502732 [ 4098 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:37:50.778315 [ 4107 ] {10b335c2-2313-431e-9a57-66744bd93c5b} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60006.475721 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60656) (comment: 02865_array_join_with_max_block_size.sql) (query 2, line 3) (in query: SELECT n, count(1) from (SELECT groupArray(number % 10) AS x FROM (SELECT * FROM numbers(100000))) ARRAY JOIN x as n group by n;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:50.833145 [ 4107 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60006.475721 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:51.141386 [ 4098 ] {5c08caea-2214-4b11-912c-d0f485b0e592} executeQuery: Code: 60. DB::Exception: Table test_3k9p8ra4.t_json_async_insert does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40296) (comment: 02421_type_json_async_insert.sh) (query 1, line 1) (in query: INSERT INTO t_json_async_insert FORMAT JSONAsObject ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f4cd9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:51.174719 [ 6956 ] {} DDLWorker(rdb_test_15_2): Error on initialization of rdb_test_15_2: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:51.189498 [ 4098 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3k9p8ra4.t_json_async_insert does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f4cd9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:51.194928 [ 5005 ] {8fab1c77-c419-4e91-9251-639b1ebe7cc1} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40240) (comment: 01635_sum_map_fuzz.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: DB::registerAggregateFunctionSumMap(DB::AggregateFunctionFactory&)::$_3::operator()(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) const @ 0x0000000026aafc01 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:37:51.203831 [ 5005 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: DB::registerAggregateFunctionSumMap(DB::AggregateFunctionFactory&)::$_3::operator()(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) const @ 0x0000000026aafc01 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:37:51.334735 [ 3895 ] {bc3d6159-830c-44bd-8e75-db755febfeb0} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 338.06 MiB (attempt to allocate chunk of 48.20 MiB bytes), maximum: 300.00 MiB.: While executing FillingRightJoinSide. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40114) (comment: 03277_join_adaptive_spill_oom.sql) (query 13, line 18) (in query: select t1.k, t2.x, t3.x from adaptive_spill_03277_1 as t1 left join adaptive_spill_03277_2 as t2 on t1.k = t2.k left join adaptive_spill_03277_3 as t3 on t1.k = t3.k Format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002399191f 9. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x000000002e700e71 10. ./src/Common/HashTable/HashTable.h:926: void DB::HashJoinMethods<(DB::JoinKind)1, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::insertFromBlockImplTypeCase, DB::RowRefList, true, false, true, false>, HashMapTable, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, std::pair>(DB::HashJoin&, HashMapTable, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>&, std::vector> const&, std::vector> const&, DB::Block const*, std::pair const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x000000002ef51d99 11. ./src/Interpreters/HashJoin/HashJoinMethodsImpl.h:51: DB::HashJoinMethods<(DB::JoinKind)1, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::insertFromBlockImpl(DB::HashJoin&, DB::HashJoin::Type, DB::HashJoin::MapsTemplate&, std::vector> const&, std::vector> const&, DB::Block const*, DB::detail::Selector const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x000000002ef4dc90 12. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:717: bool static_for_impl, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0>(DB::JoinKind, DB::JoinStrictness, int&, bool, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0&&)::'lambda'(int), 0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15, 16, 17, 18, 19, 20, 21, 22, 23>(bool DB::joinDispatch, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0>(DB::JoinKind, DB::JoinStrictness, int&, bool, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0&&)::'lambda'(int)&&, std::integer_sequence) @ 0x000000002e4691f9 13. ./base/base/../base/constexpr_helpers.h:31: DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool) @ 0x000000002e4519eb 14. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:553: DB::HashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x000000002e44ffa2 15. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:722: DB::GraceHashJoin::addBlockToJoinImpl(DB::Block) @ 0x000000002dc1a5c3 16. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:307: DB::GraceHashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x000000002dc1960c 17. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x0000000031dcec1a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:37:51.396317 [ 3895 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 338.06 MiB (attempt to allocate chunk of 48.20 MiB bytes), maximum: 300.00 MiB.: While executing FillingRightJoinSide. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000002399191f 9. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x000000002e700e71 10. ./src/Common/HashTable/HashTable.h:926: void DB::HashJoinMethods<(DB::JoinKind)1, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::insertFromBlockImplTypeCase, DB::RowRefList, true, false, true, false>, HashMapTable, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>, std::pair>(DB::HashJoin&, HashMapTable, HashTableNoState>, DefaultHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>&, std::vector> const&, std::vector> const&, DB::Block const*, std::pair const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x000000002ef51d99 11. ./src/Interpreters/HashJoin/HashJoinMethodsImpl.h:51: DB::HashJoinMethods<(DB::JoinKind)1, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::insertFromBlockImpl(DB::HashJoin&, DB::HashJoin::Type, DB::HashJoin::MapsTemplate&, std::vector> const&, std::vector> const&, DB::Block const*, DB::detail::Selector const&, DB::PODArray, 63ul, 64ul> const*, DB::PODArray, 63ul, 64ul> const*, DB::Arena&, bool&) @ 0x000000002ef4dc90 12. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:717: bool static_for_impl, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0>(DB::JoinKind, DB::JoinStrictness, int&, bool, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0&&)::'lambda'(int), 0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15, 16, 17, 18, 19, 20, 21, 22, 23>(bool DB::joinDispatch, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0>(DB::JoinKind, DB::JoinStrictness, int&, bool, DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool)::$_0&&)::'lambda'(int)&&, std::integer_sequence) @ 0x000000002e4691f9 13. ./base/base/../base/constexpr_helpers.h:31: DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool) @ 0x000000002e4519eb 14. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:553: DB::HashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x000000002e44ffa2 15. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:722: DB::GraceHashJoin::addBlockToJoinImpl(DB::Block) @ 0x000000002dc1a5c3 16. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:307: DB::GraceHashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x000000002dc1960c 17. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x0000000031dcec1a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:51.551870 [ 8431 ] {c9c4999c-27af-46dd-8660-b0f69547e95e} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000009 */ ALTER TABLE rdb_test_15.rmt (DROP PARTITION ID 'all'), (UPDATE n = 2 WHERE 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5cb284 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c4049 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:51.635944 [ 8431 ] {c9c4999c-27af-46dd-8660-b0f69547e95e} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40280) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_15.rmt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5cb284 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c4049 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:51.700018 [ 8431 ] {} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5cb284 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c4049 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:51.764632 [ 8430 ] {2de95db4-2493-4935-b898-70776ebcff46} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_async_insert' in scope SELECT count() FROM t_json_async_insert. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40320) (comment: 02421_type_json_async_insert.sh) (query 1, line 1) (in query: SELECT count() FROM t_json_async_insert), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:51.819908 [ 8430 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_async_insert' in scope SELECT count() FROM t_json_async_insert. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:52.292542 [ 3931 ] {b4ddfdaf-fa2f-4ded-ac01-13d11ed97c76} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 2, should be 1: In scope SELECT arrayDistinct(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 201, line 201) (in query: SELECT arrayDistinct(NULL, NULL);) 2025.06.13 15:37:52.303102 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 2, should be 1: In scope SELECT arrayDistinct(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:52.383859 [ 6954 ] {} DDLWorker(rdb_test_15_3): Error on initialization of rdb_test_15_3: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:52.636043 [ 5005 ] {7ece5887-d579-413a-97ab-2216ce2c3bc7} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40330) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 2, line 3) (in query: SELECT * FROM (SELECT 1) FINAL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbac44e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba12bc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:52.667653 [ 5005 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbac44e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba12bc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:52.696178 [ 8432 ] {6dc407e3-9f7e-4361-87bc-514b95051c65} executeQuery: Code: 519. DB::NetException: All attempts to get table structure failed. Log: Code: 279. DB::NetException: All connection tries failed. Log: Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) . (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) . (NO_REMOTE_SHARD_AVAILABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40356) (comment: 01361_fover_remote_num_tries.sh) (query 1, line 1) (in query: SELECT hostName() FROM remote('128.1.2.3', default.tmp)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003084b22e 4. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000030848fc5 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000028491e78 6. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284914c0 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:37:52.732533 [ 8432 ] {} TCPHandler: Code: 519. DB::NetException: All attempts to get table structure failed. Log: Code: 279. DB::NetException: All connection tries failed. Log: Timeout exceeded while connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.3.20286.altinityantalya (altinity build)) . (ALL_CONNECTION_TRIES_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) . (NO_REMOTE_SHARD_AVAILABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000003084b22e 4. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000030848fc5 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000028491e78 6. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284914c0 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:37:52.804430 [ 5005 ] {237b7f52-1be0-484e-9e0d-dbe2ae2503c0} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40330) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 3, line 4) (in query: SELECT * FROM (SELECT 1) SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbac44e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba12bc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:52.837583 [ 5005 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbac44e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba12bc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:52.972207 [ 5005 ] {77f7e76b-f5e7-42cd-a055-aca75019fc88} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40330) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 4, line 5) (in query: SELECT * FROM (SELECT 1) FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbac44e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba12bc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:52.983993 [ 5005 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbac44e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba12bc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.126200 [ 3931 ] {171e12f1-f785-477b-bf3a-4a742efc9580} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 2, should be 1: In scope SELECT arrayEnumerate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 205, line 205) (in query: SELECT arrayEnumerate(NULL, NULL);) 2025.06.13 15:37:53.147278 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 2, should be 1: In scope SELECT arrayEnumerate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:53.193430 [ 4107 ] {f11997a7-2bcc-44d0-a97a-9549ea5a7997} executeQuery: Code: 60. DB::Exception: Table test_3k9p8ra4.t_json_async_insert does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40394) (comment: 02421_type_json_async_insert.sh) (query 1, line 1) (in query: INSERT INTO t_json_async_insert FORMAT JSONAsObject ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f4cd9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.199659 [ 5163 ] {16681202-d40d-4c71-8aef-3d103838620c} executeQuery: Code: 60. DB::Exception: Table test_3k9p8ra4.t_json_async_insert does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40378) (comment: 02421_type_json_async_insert.sh) (query 1, line 1) (in query: INSERT INTO t_json_async_insert FORMAT JSONAsObject ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f4cd9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.205973 [ 4107 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3k9p8ra4.t_json_async_insert does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f4cd9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.252971 [ 5163 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3k9p8ra4.t_json_async_insert does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f4cd9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.258345 [ 5005 ] {1631e882-c8a3-4aa8-baa9-6e24d8e7dc1e} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40330) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 5, line 7) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery FINAL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4e235 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.275867 [ 5005 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4e235 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.383606 [ 5005 ] {c903cfd6-82b3-42ca-84f8-15c9e4667f22} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40330) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 6, line 8) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4e235 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.435599 [ 5005 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4e235 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.620433 [ 5005 ] {d57be56e-97a2-4200-a692-b6241ce655d2} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40330) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 7, line 9) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4e235 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.649398 [ 5005 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4e235 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.738434 [ 5005 ] {31f57a31-a6fb-4f4d-beab-e362f6184321} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40330) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 8, line 11) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) FINAL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbac44e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba12bc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.744737 [ 5005 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbac44e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba12bc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.779733 [ 4172 ] {12c9735c-52f0-45ff-b750-41230da9b636} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_async_insert' in scope SELECT data.k1 FROM t_json_async_insert ORDER BY data.k1 ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53374) (comment: 02421_type_json_async_insert.sh) (query 1, line 1) (in query: SELECT data.k1 FROM t_json_async_insert ORDER BY data.k1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.802705 [ 4172 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_async_insert' in scope SELECT data.k1 FROM t_json_async_insert ORDER BY data.k1 ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.822220 [ 5005 ] {c97ffbc1-a99e-4053-88e3-ed0f6bb6c471} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40330) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 9, line 12) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbac44e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba12bc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.838988 [ 5005 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbac44e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba12bc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:53.978200 [ 5005 ] {c44d7000-1115-49af-8206-e72d925fb086} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40330) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 10, line 13) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbac44e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba12bc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:54.007909 [ 5005 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbac44e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba12bc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:37:54.201673 [ 5005 ] {4a14a1b3-c226-48be-a7aa-8c2a863cb78e} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40330) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 11, line 15) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery FINAL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4e235 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:54.205235 [ 5005 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4e235 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:54.338215 [ 5005 ] {fa294ac8-a423-4855-8799-798514f1b3f5} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40330) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 12, line 16) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4e235 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:54.377867 [ 5005 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4e235 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:54.612127 [ 5005 ] {2aa0a705-4e03-4300-8485-842c3b2a97f0} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40330) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 13, line 17) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4e235 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:54.624671 [ 5005 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4392: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4e235 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:37:55.421231 [ 4172 ] {0e4a9aec-4d79-4d79-bb0c-4d0de4627d44} executeQuery: Code: 378. DB::Exception: Data type Bool cannot have arguments: In scope SELECT CAST('0', 'Bool(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53442) (comment: 02689_meaningless_data_types.sql) (query 1, line 1) (in query: SELECT 0::Bool(Upyachka);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:213: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl[abi:ne190107], std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002c41bb7e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41b755 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:55.430448 [ 4172 ] {} TCPHandler: Code: 378. DB::Exception: Data type Bool cannot have arguments: In scope SELECT CAST('0', 'Bool(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:213: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl[abi:ne190107], std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002c41bb7e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41b755 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:55.597856 [ 4172 ] {8a6007c4-fbca-4ba7-95ee-7d4e9f917e35} executeQuery: Code: 378. DB::Exception: Data type Ring cannot have arguments: In scope SELECT CAST('[(1, 2), (3, 4)]', 'Ring(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53442) (comment: 02689_meaningless_data_types.sql) (query 2, line 2) (in query: SELECT [(1, 2), (3, 4)]::Ring(Upyachka);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:213: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl[abi:ne190107], std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002c41bb7e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41b755 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:55.611399 [ 4172 ] {} TCPHandler: Code: 378. DB::Exception: Data type Ring cannot have arguments: In scope SELECT CAST('[(1, 2), (3, 4)]', 'Ring(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:213: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl[abi:ne190107], std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002c41bb7e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41b755 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:37:55.695570 [ 3931 ] {9509292a-e0bc-4a44-ab05-e07ddd9e4d85} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT arrayFlatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 216, line 216) (in query: SELECT arrayFlatten(NULL, NULL);) 2025.06.13 15:37:55.716559 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT arrayFlatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:55.798079 [ 4172 ] {bc5e1447-c0e3-412a-9ca1-d61d8286b6ae} executeQuery: Code: 378. DB::Exception: Data type IPv4 cannot have arguments: In scope SELECT CAST('1.1.1.1', 'IPv4(\'Hello, world!\')'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53442) (comment: 02689_meaningless_data_types.sql) (query 3, line 3) (in query: SELECT '1.1.1.1'::IPv4('Hello, world!');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:192: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002c41b461 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:55.812532 [ 4172 ] {} TCPHandler: Code: 378. DB::Exception: Data type IPv4 cannot have arguments: In scope SELECT CAST('1.1.1.1', 'IPv4(\'Hello, world!\')'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:192: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002c41b461 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000002c41bf76 8. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002ad78912 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:37:55.828471 [ 3931 ] {f3833d3d-e9fd-4df1-88ba-2eda61606521} executeQuery: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(NULL, NULL). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 217, line 217) (in query: SELECT arrayFold(NULL, NULL);) 2025.06.13 15:37:55.842993 [ 3931 ] {} TCPHandler: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(NULL, NULL). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:37:55.852061 [ 3727 ] {} ExternalDictionariesLoader: Could not update external dictionary 'c6828e9e-2821-46ee-9d8a-3d496cf21aae', leaving the previous version, next update is scheduled at 2025-06-13 15:38:00: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): while reading column last_insert_time at /var/lib/clickhouse/store/6dd/6dda5caf-9dd7-423a-b600-93a10ec351c2/: While executing Log. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. ./build_docker/./src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x0000000023e63227 14. DB::ReadBuffer::next() @ 0x0000000017e74832 15. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9e815 16. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000032d9e14c 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c5f5ea3 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 19. ./build_docker/./src/Storages/StorageLog.cpp:269: DB::LogSource::readData(DB::NameAndTypePair const&, COW::immutable_ptr&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x000000003084f6e1 20. ./build_docker/./src/Storages/StorageLog.cpp:202: DB::LogSource::generate() @ 0x000000003084e340 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 28. void DB::mergeBlockWithPipe<(DB::DictionaryKeyType)0>(unsigned long, DB::Block&, DB::QueryPipeline) @ 0x0000000028a8998a 29. DB::FlatDictionary::updateData() @ 0x0000000028a4eb9c 30. DB::FlatDictionary::loadData() @ 0x0000000028a43b13 31. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000028a434fb (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:56.411483 [ 6956 ] {} DDLWorker(rdb_test_15_2): Error on initialization of rdb_test_15_2: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:56.423401 [ 3931 ] {c0ab782b-d717-40fc-be41-26aae0c6d31f} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 2, should be 1: In scope SELECT arrayJoin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 220, line 220) (in query: SELECT arrayJoin(NULL, NULL);) 2025.06.13 15:37:56.453565 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 2, should be 1: In scope SELECT arrayJoin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:56.718117 [ 4171 ] {bf5ed0cf-8de0-45a2-a4ec-d514c0b8d362} executeQuery: Code: 36. DB::Exception: Expression in arrayJoin cannot depend on lambda argument: array(x, 1_UInt8) . (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53468) (comment: 01330_array_join_in_higher_order_function.sql) (query 1, line 1) (in query: SELECT arrayMap(x -> arrayJoin([x, 1]), [1, 2]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:1020: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb7cc94 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:795: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb79af1 7. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x000000002cb7072c 8. ./build_docker/./src/Planner/Utils.cpp:252: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000002cb8e964 9. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:377: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002ddfe1f7 10. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6eedb 11. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:37:56.733680 [ 4171 ] {} TCPHandler: Code: 36. DB::Exception: Expression in arrayJoin cannot depend on lambda argument: array(x, 1_UInt8) . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:1020: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb7cc94 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:795: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb79af1 7. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x000000002cb7072c 8. ./build_docker/./src/Planner/Utils.cpp:252: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000002cb8e964 9. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:377: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002ddfe1f7 10. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6eedb 11. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:37:56.742370 [ 8099 ] {688ada27-1b24-4fda-b4fd-9299b9f54c14} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_15/rdb/log/query-0000000010 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.23989621 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40348) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: delete from rdb_test_15.mt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df0acf7 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6190db 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:37:56.849187 [ 8099 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_15/rdb/log/query-0000000010 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.23989621 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df0acf7 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6190db 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:37:57.750472 [ 6954 ] {} DDLWorker(rdb_test_15_3): Error on initialization of rdb_test_15_3: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:37:58.527120 [ 8431 ] {7f012462-6269-45c3-9a3c-b93eefef9430} 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.20286.altinityantalya (altinity build)) (from [::1]:53510) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 9. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 12. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:37:58.552221 [ 8431 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 9. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 12. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:37:58.958276 [ 3931 ] {3c53060d-970d-4c26-b689-caeaeb2d7d2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 2, should be 1: In scope SELECT arrayPopBack(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 232, line 232) (in query: SELECT arrayPopBack(NULL, NULL);) 2025.06.13 15:37:58.970213 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 2, should be 1: In scope SELECT arrayPopBack(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:37:59.079291 [ 3931 ] {fa7bd3e6-cf79-4c87-9d33-926232aa3091} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 2, should be 1: In scope SELECT arrayPopFront(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 233, line 233) (in query: SELECT arrayPopFront(NULL, NULL);) 2025.06.13 15:37:59.091741 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 2, should be 1: In scope SELECT arrayPopFront(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:00.065968 [ 3931 ] {cdaea31e-0295-431b-b8fc-df83ae1f89f8} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 239, line 239) (in query: SELECT arrayReduce(NULL, NULL);) 2025.06.13 15:38:00.141052 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:38:00.333144 [ 3931 ] {33472d93-893e-4e12-9cd9-d256a4db836d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array' to function 'arrayResize'. Expected: Array, got: Nullable(Nothing): In scope SELECT arrayResize(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 241, line 241) (in query: SELECT arrayResize(NULL, NULL);) 2025.06.13 15:38:00.355074 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array' to function 'arrayResize'. Expected: Array, got: Nullable(Nothing): In scope SELECT arrayResize(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:38:00.440269 [ 3931 ] {ff108dd5-592d-481c-a284-5b24f61c6b4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 2, should be 1: In scope SELECT arrayReverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 242, line 242) (in query: SELECT arrayReverse(NULL, NULL);) 2025.06.13 15:38:00.449521 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 2, should be 1: In scope SELECT arrayReverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:01.725511 [ 6956 ] {} DDLWorker(rdb_test_15_2): Error on initialization of rdb_test_15_2: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:01.728828 [ 4172 ] {af9368ea-f605-43e2-9e82-269fb85b7fd0} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_15/rdb/log/query-0000000011 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.051906427 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53484) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: delete from rdb_test_15.rmt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df0acf7 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6190db 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:38:01.744228 [ 4172 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_15/rdb/log/query-0000000011 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.051906427 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df0acf7 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6190db 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:03.114996 [ 6954 ] {} DDLWorker(rdb_test_15_3): Error on initialization of rdb_test_15_3: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:03.328204 [ 3931 ] {7d82cb26-eceb-4a57-80bf-dfd64101ef42} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument of function arrayWithConstant, expected Integer: In scope SELECT arrayWithConstant(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 260, line 260) (in query: SELECT arrayWithConstant(NULL, NULL);) 2025.06.13 15:38:03.340917 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument of function arrayWithConstant, expected Integer: In scope SELECT arrayWithConstant(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:38:04.209144 [ 3931 ] {95ada2d8-ff90-479d-899f-9341b22ecc0a} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 264, line 264) (in query: SELECT array_concat_agg(NULL, NULL);) 2025.06.13 15:38:04.235010 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:38:04.385086 [ 3931 ] {1ad8c2d9-f092-4c5a-83c0-6f6b5245a19b} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 2, should be 1: In scope SELECT ascii(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 265, line 265) (in query: SELECT ascii(NULL, NULL);) 2025.06.13 15:38:04.401532 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 2, should be 1: In scope SELECT ascii(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:04.521899 [ 3931 ] {00d983dc-f187-4b48-b8d6-e0808e8ff9a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 2, should be 1: In scope SELECT asin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 266, line 266) (in query: SELECT asin(NULL, NULL);) 2025.06.13 15:38:04.538108 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 2, should be 1: In scope SELECT asin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:04.736381 [ 3931 ] {a0a7b037-aed2-44c5-9cc9-3d354b210d77} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 2, should be 1: In scope SELECT asinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 267, line 267) (in query: SELECT asinh(NULL, NULL);) 2025.06.13 15:38:04.757969 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 2, should be 1: In scope SELECT asinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:04.971326 [ 3931 ] {a30adc56-2caa-4a78-bf0d-bb34d545cdb8} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 2, should be 1: In scope SELECT assumeNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 268, line 268) (in query: SELECT assumeNotNull(NULL, NULL);) 2025.06.13 15:38:04.977000 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 2, should be 1: In scope SELECT assumeNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:05.071232 [ 3931 ] {90abd9a1-58c9-499b-b523-9c0486bc0e5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 2, should be 1: In scope SELECT atan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 269, line 269) (in query: SELECT atan(NULL, NULL);) 2025.06.13 15:38:05.093611 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 2, should be 1: In scope SELECT atan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:05.332646 [ 3931 ] {fb10ec09-8575-45c8-a4a0-e43c2cc8021f} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 2, should be 1: In scope SELECT atanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 271, line 271) (in query: SELECT atanh(NULL, NULL);) 2025.06.13 15:38:05.348739 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 2, should be 1: In scope SELECT atanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:06.023156 [ 3931 ] {34ad35fe-3772-4dee-bbb9-071afddf22be} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 2, should be 1: In scope SELECT base58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 275, line 275) (in query: SELECT base58Decode(NULL, NULL);) 2025.06.13 15:38:06.032397 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 2, should be 1: In scope SELECT base58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:06.095284 [ 3931 ] {0af0b6a5-56e1-41b3-a65c-9fc76c0b91cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 2, should be 1: In scope SELECT base58Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 276, line 276) (in query: SELECT base58Encode(NULL, NULL);) 2025.06.13 15:38:06.105057 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 2, should be 1: In scope SELECT base58Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:06.236263 [ 3931 ] {83eee0f3-b144-41e5-b93d-7144d118da9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT base64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 277, line 277) (in query: SELECT base64Decode(NULL, NULL);) 2025.06.13 15:38:06.247711 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT base64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:06.305601 [ 5163 ] {84dea928-182a-44af-9342-29b42abf4f01} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_15/rdb/log/query-0000000012 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.359900837 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53674) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_15.mt update n=2 where n=3), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df0acf7 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6190db 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:38:06.311587 [ 5163 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_15/rdb/log/query-0000000012 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.359900837 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df0acf7 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6190db 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:06.338488 [ 3931 ] {74c13bb6-12d0-4fc8-95ab-a9bde4266293} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT base64Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 278, line 278) (in query: SELECT base64Encode(NULL, NULL);) 2025.06.13 15:38:06.353197 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT base64Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:06.467930 [ 3931 ] {ba8bb4c6-e83d-482e-a059-4ea4e01ff0a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 279, line 279) (in query: SELECT base64URLDecode(NULL, NULL);) 2025.06.13 15:38:06.494222 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:06.545093 [ 3931 ] {2ab123d2-1d3a-4d03-9cc4-7ed438a04b02} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 280, line 280) (in query: SELECT base64URLEncode(NULL, NULL);) 2025.06.13 15:38:06.574370 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:06.657079 [ 3931 ] {8f0f0a75-c351-405b-92a2-1813fac4bf0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 2, should be 1: In scope SELECT basename(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 281, line 281) (in query: SELECT basename(NULL, NULL);) 2025.06.13 15:38:06.666846 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 2, should be 1: In scope SELECT basename(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:06.799720 [ 3931 ] {80721673-78c4-4de9-9608-c6b09dcc27b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 2, should be 1: In scope SELECT bin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 282, line 282) (in query: SELECT bin(NULL, NULL);) 2025.06.13 15:38:06.811122 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 2, should be 1: In scope SELECT bin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:06.922270 [ 6956 ] {} DDLWorker(rdb_test_15_2): Error on initialization of rdb_test_15_2: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:07.062742 [ 3931 ] {eb50f3a3-50d5-4a10-8a76-01b1a8ff1689} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 2, should be 1: In scope SELECT bitCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 284, line 284) (in query: SELECT bitCount(NULL, NULL);) 2025.06.13 15:38:07.124084 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 2, should be 1: In scope SELECT bitCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:07.347888 [ 3931 ] {0126ce0c-bf77-4abc-ad90-edb9a96a535f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 2, should be 1: In scope SELECT bitNot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 286, line 286) (in query: SELECT bitNot(NULL, NULL);) 2025.06.13 15:38:07.358432 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 2, should be 1: In scope SELECT bitNot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:07.609563 [ 3931 ] {0fc69620-d3bf-4ced-8629-d3d3ee750557} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 2, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 288, line 288) (in query: SELECT bitPositionsToArray(NULL, NULL);) 2025.06.13 15:38:07.616135 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 2, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:08.419597 [ 6954 ] {} DDLWorker(rdb_test_15_3): Error on initialization of rdb_test_15_3: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:10.115424 [ 3931 ] {e060e770-dead-44a4-9887-4514342184fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 2, should be 1: In scope SELECT bitmapBuild(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 302, line 302) (in query: SELECT bitmapBuild(NULL, NULL);) 2025.06.13 15:38:10.123957 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 2, should be 1: In scope SELECT bitmapBuild(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:10.196956 [ 3931 ] {346fc024-153d-4bf9-bbe9-ff0014a95da0} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 2, should be 1: In scope SELECT bitmapCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 303, line 303) (in query: SELECT bitmapCardinality(NULL, NULL);) 2025.06.13 15:38:10.207769 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 2, should be 1: In scope SELECT bitmapCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:10.756020 [ 3931 ] {2b3586ca-7927-4b9e-b948-0938c3d08a7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 2, should be 1: In scope SELECT bitmapMax(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 307, line 307) (in query: SELECT bitmapMax(NULL, NULL);) 2025.06.13 15:38:10.763887 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 2, should be 1: In scope SELECT bitmapMax(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:10.870100 [ 3931 ] {d69275f8-a0bf-43f9-b615-0fde9c1c9db3} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 2, should be 1: In scope SELECT bitmapMin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 308, line 308) (in query: SELECT bitmapMin(NULL, NULL);) 2025.06.13 15:38:10.876552 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 2, should be 1: In scope SELECT bitmapMin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:11.107640 [ 4171 ] {0e6b1fa3-8b3e-40ae-ad9f-bf06340d3c69} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_15/rdb/log/query-0000000013 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.131911446 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59464) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_15.rmt update n=2 where n=3), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df0acf7 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6190db 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:38:11.122737 [ 4171 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_15/rdb/log/query-0000000013 is not finished on 2 of 3 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.131911446 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df0acf7 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6190db 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:11.331020 [ 3931 ] {71fb803f-77a1-49ec-9074-37262cd90520} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetInRange(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 311, line 311) (in query: SELECT bitmapSubsetInRange(NULL, NULL);) 2025.06.13 15:38:11.341160 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetInRange(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:11.403433 [ 3931 ] {ff3f8e2b-bcfc-49e9-9f74-68a02994c66e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetLimit(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 312, line 312) (in query: SELECT bitmapSubsetLimit(NULL, NULL);) 2025.06.13 15:38:11.444413 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetLimit(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:11.542916 [ 3931 ] {85aa0fac-9134-4391-82d9-ffd8eb447856} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 2, should be 1: In scope SELECT bitmapToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 313, line 313) (in query: SELECT bitmapToArray(NULL, NULL);) 2025.06.13 15:38:11.563125 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 2, should be 1: In scope SELECT bitmapToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:11.650251 [ 3931 ] {6f65f6f7-ae93-464e-b21e-903fe385260c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 2, should be 3: In scope SELECT bitmapTransform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 314, line 314) (in query: SELECT bitmapTransform(NULL, NULL);) 2025.06.13 15:38:11.661963 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 2, should be 3: In scope SELECT bitmapTransform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:12.183345 [ 6956 ] {} DDLWorker(rdb_test_15_2): Error on initialization of rdb_test_15_2: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:12.296985 [ 3931 ] {ec4de5a3-ccf6-4b6f-8c4e-1b52387f2305} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 2, should be 1: In scope SELECT bitmaskToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 317, line 317) (in query: SELECT bitmaskToArray(NULL, NULL);) 2025.06.13 15:38:12.301635 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 2, should be 1: In scope SELECT bitmaskToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:12.323558 [ 5978 ] {66786a4b-96b6-419a-acc0-24121fd84a5f} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59586) (comment: 02530_dictionaries_update_field.sh) (query 1, line 1) (in query: DROP DICTIONARY dict_flat), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:12.344645 [ 5978 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:12.374251 [ 3931 ] {92b097af-aac0-4a82-866a-0165e861bf0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 2, should be 1: In scope SELECT bitmaskToList(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 318, line 318) (in query: SELECT bitmaskToList(NULL, NULL);) 2025.06.13 15:38:12.393933 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 2, should be 1: In scope SELECT bitmaskToList(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:12.492631 [ 3931 ] {8e244bc4-f094-4e7d-932f-7b9598273199} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 2, should be 0: In scope SELECT blockNumber(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 319, line 319) (in query: SELECT blockNumber(NULL, NULL);) 2025.06.13 15:38:12.500269 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 2, should be 0: In scope SELECT blockNumber(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:12.888422 [ 3931 ] {986dcd7d-e88b-400b-92e7-be7eedb114ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 2, should be 0: In scope SELECT blockSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 321, line 321) (in query: SELECT blockSize(NULL, NULL);) 2025.06.13 15:38:12.895847 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 2, should be 0: In scope SELECT blockSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:13.039485 [ 3508 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fb841949-1f90-4e7f-a94f-b2b9aa4ee8db::202506_1_21_4}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab57af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab1fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003122f56b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d8e4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:13.142341 [ 8431 ] {f5526b3e-60ba-41c6-a8c8-cdff2d896d47} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `number` in scope SELECT arrayFilter(x -> notEmpty(concat(x, 'hello')), ['']) FROM system.one ARRAY JOIN [0] AS elem, arrayMap(x -> concat(x, ignore(ignore(toLowCardinality('03147_parquet_memory_tracking.parquet'), 37, 37, toUInt128(37), 37, 37, toLowCardinality(37), 37), 8, ignore(ignore(1., 36, 8, 8)), *), 'hello'), ['']) AS unused WHERE NOT ignore(elem) GROUP BY sum(ignore(ignore(ignore(1., 1, 36, 8, 8), ignore(52, 37, 37, '03147_parquet_memory_tracking.parquet', 37, 37, toUInt256(37), 37, 37, toNullable(37), 37, 37), 1., 1, 36, 8, 8), emptyArrayToSingle(arrayMap(x -> toString(x), arrayMap(x -> nullIf(x, 2), arrayJoin([[1]])))))) IGNORE NULLS, modulo(toLowCardinality('03147_parquet_memory_tracking.parquet'), number, toLowCardinality(3)). (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59444) (comment: 02374_analyzer_array_join.sql) (query 32, line 70) (in query: SELECT arrayFilter(x -> notEmpty(concat(x, 'hello')), ['']) FROM system.one ARRAY JOIN [0] AS elem, arrayMap(x -> concat(x, ignore(ignore(toLowCardinality('03147_parquet_memory_tracking.parquet'), 37, 37, toUInt128(37), 37, 37, toLowCardinality(37), 37), 8, ignore(ignore(1., 36, 8, 8)), *), 'hello'), ['']) AS unused WHERE NOT ignore(elem) GROUP BY sum(ignore(ignore(ignore(1., 1, 36, 8, 8), ignore(52, 37, 37, '03147_parquet_memory_tracking.parquet', 37, 37, toUInt256(37), 37, 37, toNullable(37), 37, 37), 1., 1, 36, 8, 8), emptyArrayToSingle(arrayMap(x -> toString(x), arrayMap(x -> nullIf(x, 2), arrayJoin([[1]])))))) IGNORE NULLS, modulo(toLowCardinality('03147_parquet_memory_tracking.parquet'), number, toLowCardinality(3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4227: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x000000002cc49279 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9df5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:38:13.149366 [ 8431 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `number` in scope SELECT arrayFilter(x -> notEmpty(concat(x, 'hello')), ['']) FROM system.one ARRAY JOIN [0] AS elem, arrayMap(x -> concat(x, ignore(ignore(toLowCardinality('03147_parquet_memory_tracking.parquet'), 37, 37, toUInt128(37), 37, 37, toLowCardinality(37), 37), 8, ignore(ignore(1., 36, 8, 8)), *), 'hello'), ['']) AS unused WHERE NOT ignore(elem) GROUP BY sum(ignore(ignore(ignore(1., 1, 36, 8, 8), ignore(52, 37, 37, '03147_parquet_memory_tracking.parquet', 37, 37, toUInt256(37), 37, 37, toNullable(37), 37, 37), 1., 1, 36, 8, 8), emptyArrayToSingle(arrayMap(x -> toString(x), arrayMap(x -> nullIf(x, 2), arrayJoin([[1]])))))) IGNORE NULLS, modulo(toLowCardinality('03147_parquet_memory_tracking.parquet'), number, toLowCardinality(3)). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4227: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x000000002cc49279 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9df5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:38:13.369719 [ 3931 ] {873601fc-8c66-4c7d-9198-61b713e5cf3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 2, should be 0: In scope SELECT buildId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 323, line 323) (in query: SELECT buildId(NULL, NULL);) 2025.06.13 15:38:13.413078 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 2, should be 0: In scope SELECT buildId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:14.151113 [ 3931 ] {ed14f6ea-94a9-4349-b316-a8e17d22b371} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 327, line 327) (in query: SELECT byteSwap(NULL, NULL);) 2025.06.13 15:38:14.184231 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:14.640239 [ 7755 ] {3e25b475-8a77-4197-91d0-bd5b30297945} executeQuery: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'z'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53582) (comment: 02496_format_datetime_in_joda_syntax.sql) (query 75, line 81) (in query: -- { echoOff } SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'z');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ade23c6 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add7a20 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:14.651404 [ 7755 ] {} TCPHandler: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'z'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ade23c6 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add7a20 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:14.713392 [ 8101 ] {4e23333c-5189-4d82-9933-37b240ffc126} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000015 */ ALTER TABLE rdb_test_15.mt (DROP PARTITION ID 'all'), (ADD COLUMN `m` int)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:14.740763 [ 3931 ] {0867c299-e5b7-48c4-8667-f95538d1afdd} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 330, line 330) (in query: SELECT caseWithoutExpr(NULL, NULL);) 2025.06.13 15:38:14.745047 [ 7755 ] {35b33fed-17b2-4bad-8c20-02d4ae9612db} executeQuery: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'zz'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53582) (comment: 02496_format_datetime_in_joda_syntax.sql) (query 76, line 84) (in query: SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'zz');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ade23c6 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add7a20 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:14.758245 [ 7755 ] {} TCPHandler: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'zz'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ade23c6 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add7a20 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:14.759116 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:14.783297 [ 8101 ] {4e23333c-5189-4d82-9933-37b240ffc126} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40418) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_15.mt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:14.798167 [ 8101 ] {} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:14.845222 [ 3931 ] {b2bb9886-97cf-49d6-bd5f-aa616a1089e1} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 331, line 331) (in query: SELECT caseWithoutExpression(NULL, NULL);) 2025.06.13 15:38:14.850363 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:14.861004 [ 7755 ] {c8a4e303-e07e-41be-a77f-07a0ac6d0ca0} executeQuery: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'zzz'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53582) (comment: 02496_format_datetime_in_joda_syntax.sql) (query 77, line 85) (in query: SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'zzz');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ade23c6 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add7a20 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:14.873503 [ 7755 ] {} TCPHandler: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'zzz'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ade23c6 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add7a20 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:14.902485 [ 3931 ] {511fa152-a386-4430-9b6b-2d0e2295585d} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 332, line 332) (in query: SELECT catboostEvaluate(NULL, NULL);) 2025.06.13 15:38:14.922223 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:38:14.989184 [ 3931 ] {623ed5da-4ffd-4ab8-b684-01e91c20617e} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 333, line 333) (in query: SELECT categoricalInformationValue(NULL, NULL);) 2025.06.13 15:38:15.011506 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:38:15.093799 [ 3931 ] {ee9feaa8-812f-429f-93db-04eddafd6d04} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 2, should be 1: In scope SELECT cbrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 334, line 334) (in query: SELECT cbrt(NULL, NULL);) 2025.06.13 15:38:15.104076 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 2, should be 1: In scope SELECT cbrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:15.180137 [ 7755 ] {87c5b683-d2b4-4897-bbba-436384e1431b} executeQuery: Code: 48. DB::Exception: format is not supported for TIMEZONE_OFFSET_ID: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'Z'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53582) (comment: 02496_format_datetime_in_joda_syntax.sql) (query 78, line 86) (in query: SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'Z');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ade229d 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add7a20 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:15.211965 [ 7755 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for TIMEZONE_OFFSET_ID: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'Z'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ade229d 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add7a20 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:15.441863 [ 7755 ] {c26a1cb1-2efb-43c8-a330-b8814766a5fd} executeQuery: Code: 48. DB::Exception: format is not supported for b: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'b'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53582) (comment: 02496_format_datetime_in_joda_syntax.sql) (query 79, line 87) (in query: SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'b');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ade2338 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add7a20 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:15.451483 [ 7755 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for b: In scope SELECT formatDateTimeInJodaSyntax(toDateTime('2018-01-12 22:33:44'), 'b'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ade2338 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add7a20 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:15.687318 [ 7755 ] {18986593-38d0-4c14-b615-60d6d786e1d0} executeQuery: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'z'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53582) (comment: 02496_format_datetime_in_joda_syntax.sql) (query 80, line 89) (in query: SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'z');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001addee24 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add79de 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:15.700998 [ 7755 ] {} TCPHandler: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'z'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001addee24 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add79de 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:15.860115 [ 7755 ] {0b38c2a0-72c3-4f79-b546-3acc8d50f761} executeQuery: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'zz'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53582) (comment: 02496_format_datetime_in_joda_syntax.sql) (query 81, line 90) (in query: SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'zz');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001addee24 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add79de 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:15.882575 [ 7755 ] {} TCPHandler: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'zz'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001addee24 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add79de 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:15.992190 [ 7755 ] {ef4196f0-4b19-44a0-a71a-47142e99c009} executeQuery: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'zzz'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53582) (comment: 02496_format_datetime_in_joda_syntax.sql) (query 82, line 91) (in query: SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'zzz');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001addee24 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add79de 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:16.011991 [ 7755 ] {} TCPHandler: Code: 48. DB::Exception: Short name time zone is not yet supported: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'zzz'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001addee24 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add79de 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:16.069844 [ 6236 ] {7c4401f7-2859-4b21-8034-82c71a012879} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36232) (comment: 02904_distributed_settings_background_insert_compatibility.gen.sql) (in query: DROP DATABASE IF EXISTS test_snmtd817 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:16.079157 [ 6236 ] {7c4401f7-2859-4b21-8034-82c71a012879} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:16.301176 [ 7755 ] {d6f707c9-121f-4b46-9641-c935a06d36b2} executeQuery: Code: 48. DB::Exception: format is not supported for TIMEZONE_OFFSET_ID: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'Z'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53582) (comment: 02496_format_datetime_in_joda_syntax.sql) (query 83, line 92) (in query: SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'Z');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001added7d 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add79de 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:16.311818 [ 7755 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for TIMEZONE_OFFSET_ID: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'Z'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001added7d 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add79de 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:16.316744 [ 8430 ] {f09ddc42-ad50-4b1c-b007-86ed857046c2} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000016 */ ALTER TABLE rdb_test_15.rmt (DROP PARTITION ID 'all'), (ADD COLUMN `m` int)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5cb284 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c4049 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:38:16.383136 [ 8430 ] {f09ddc42-ad50-4b1c-b007-86ed857046c2} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40436) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_15.rmt drop partition id 'all', add column m int), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5cb284 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c4049 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:38:16.419748 [ 8430 ] {} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5cb284 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c4049 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:38:16.581873 [ 7755 ] {63e022f0-1e9a-40dd-b2c5-7410fed58bc6} executeQuery: Code: 48. DB::Exception: format is not supported for b: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'b'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53582) (comment: 02496_format_datetime_in_joda_syntax.sql) (query 84, line 93) (in query: SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'b');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001addeeb8 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add79de 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:16.594142 [ 7755 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for b: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), 'b'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001addeeb8 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add79de 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:16.952662 [ 7755 ] {2ad92ebf-75da-41df-a057-67ae9db906a1} executeQuery: Code: 36. DB::Exception: No closing single quote for literal: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), '\'aaaa\'\''). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53582) (comment: 02496_format_datetime_in_joda_syntax.sql) (query 85, line 95) (in query: SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), '\'aaaa\'\'');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001adde807 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add79de 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:16.961045 [ 7755 ] {} TCPHandler: Code: 36. DB::Exception: No closing single quote for literal: In scope SELECT formatDateTimeInJodaSyntax(toDate32('2018-01-12 22:33:44'), '\'aaaa\'\''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeType(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001adde807 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001add79de 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:38:17.041091 [ 8101 ] {c57d8de9-bc02-436f-98da-f6bb09db1123} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40464) (comment: 02576_rewrite_array_exists_to_has.sql) (query 8, line 11) (in query: set enable_analyzer = false;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:17.052757 [ 8101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:17.188052 [ 3931 ] {35a04535-892e-4662-9bb2-3ec3cd8b4d5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 2, should be 3: In scope SELECT clamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 345, line 345) (in query: SELECT clamp(NULL, NULL);) 2025.06.13 15:38:17.218204 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 2, should be 3: In scope SELECT clamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:17.387054 [ 6956 ] {} DDLWorker(rdb_test_15_2): Error on initialization of rdb_test_15_2: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:17.445977 [ 9644 ] {c323f221-9430-4e6d-a7d7-d06f425e29e7} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02445_replicated_db_alter_partition.sh) (in query: /* ddl_entry=query-0000000017 */ ALTER TABLE rdb_test_15.mt (DROP PARTITION ID 'all'), (UPDATE n = 2 WHERE 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:17.515611 [ 9644 ] {c323f221-9430-4e6d-a7d7-d06f425e29e7} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40506) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_15.mt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:17.555822 [ 9644 ] {} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:18.093729 [ 4171 ] {ef03a761-f42a-46e7-be96-d3738512d7ae} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40560) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_15.rmt drop partition id 'all', update n = 2 where 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:38:18.143417 [ 4171 ] {} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42c72 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:38:18.958106 [ 3931 ] {5e670ed4-d201-4a4d-9ebe-afd0433b32c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connectionId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 353, line 353) (in query: SELECT connectionId(NULL, NULL);) 2025.06.13 15:38:18.973506 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connectionId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:18.993247 [ 5163 ] {75464f10-3ba6-45a7-83e4-1bb589196c41} 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.20286.altinityantalya (altinity build)) (from [::1]:40628) (comment: 01538_fuzz_aggregate.sql) (query 1, line 1) (in query: SELECT count(), sum(ns) FROM ( SELECT intDiv(number, NULL) AS k FROM system.numbers_mt GROUP BY k ) ARRAY JOIN ns;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5014: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4f2e3 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5333: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc35 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:38:18.997224 [ 5163 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `ns` in scope SELECT count(), sum(ns) FROM (SELECT intDiv(number, NULL) AS k FROM system.numbers_mt GROUP BY k) ARRAY JOIN ns. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5014: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4f2e3 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5333: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc35 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:38:19.097334 [ 3931 ] {935cd820-7395-43c1-b7e5-5ac5116f5962} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connection_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 354, line 354) (in query: SELECT connection_id(NULL, NULL);) 2025.06.13 15:38:19.109148 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connection_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:19.456847 [ 3931 ] {2ee33ae0-d57d-4e25-962a-1af640ad13e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 2, should be 3: In scope SELECT convertCharset(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 356, line 356) (in query: SELECT convertCharset(NULL, NULL);) 2025.06.13 15:38:19.464871 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 2, should be 3: In scope SELECT convertCharset(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:20.171363 [ 3931 ] {8814b9b0-45f7-410d-8035-f1b948553b9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 2, should be 1: In scope SELECT cos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 360, line 360) (in query: SELECT cos(NULL, NULL);) 2025.06.13 15:38:20.193625 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 2, should be 1: In scope SELECT cos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:20.353629 [ 3931 ] {31cd492a-3e78-449c-a915-9d17dbf6d13a} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 2, should be 1: In scope SELECT cosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 361, line 361) (in query: SELECT cosh(NULL, NULL);) 2025.06.13 15:38:20.376834 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 2, should be 1: In scope SELECT cosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:20.682432 [ 3931 ] {77d85314-c1db-4070-b4d7-51e6c3f93a58} executeQuery: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 363, line 363) (in query: SELECT count(NULL, NULL);) 2025.06.13 15:38:20.691782 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:20.797227 [ 3931 ] {42cc04b4-c7bb-4aed-b393-1e4088be50b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 2, should be 1: In scope SELECT countDigits(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 364, line 364) (in query: SELECT countDigits(NULL, NULL);) 2025.06.13 15:38:20.832023 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 2, should be 1: In scope SELECT countDigits(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:20.964547 [ 3931 ] {170c7469-cffd-4005-9fd0-f210a28fabd7} executeQuery: Code: 43. DB::Exception: First argument for function countEqual must be an array. Actual Nullable(Nothing): In scope SELECT countEqual(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 365, line 365) (in query: SELECT countEqual(NULL, NULL);) 2025.06.13 15:38:20.973647 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function countEqual must be an array. Actual Nullable(Nothing): In scope SELECT countEqual(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:38:21.780438 [ 9644 ] {95925bfa-67f8-4827-86ae-e41fac058222} 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.20286.altinityantalya (altinity build)) (from [::1]:40648) (comment: 00953_moving_functions.sql) (query 11, line 35) (in query: SELECT k, groupArrayMovingAvg(v) FROM (SELECT * FROM moving_sum_num ORDER BY k, dt) GROUP BY k ORDER BY k FORMAT TabSeparatedWithNamesAndTypes;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f585dc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f5af07 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f54898 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f54302 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dd53bf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dcd2b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 2025.06.13 15:38:21.814644 [ 9644 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f585dc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f5af07 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f54898 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f54302 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dd53bf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dcd2b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:22.604320 [ 8431 ] {f2596994-9f55-434e-a057-21e4d476f189} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_15/rdb/log/query-0000000018 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.563909107 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40640) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: alter table rdb_test_15.mt update n=2 where n=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df0acf7 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6190db 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:38:22.638406 [ 8431 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_15/rdb/log/query-0000000018 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.563909107 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df0acf7 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6190db 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:22.830291 [ 6956 ] {} DDLWorker(rdb_test_15_2): Error on initialization of rdb_test_15_2: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:22.895328 [ 8101 ] {dab880d2-bee5-48a0-82f0-0ba26bbed3b5} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40866) (comment: 02935_format_with_arbitrary_types.sql) (query 1, line 2) (in query: -- Tags: no-fasttest -- no-fasttest: json type needs rapidjson library, geo types need s2 geometry SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:22.923724 [ 8101 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:24.278283 [ 3931 ] {60c8bd2f-b6ad-42c0-ba0d-c8b36e1fc70e} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT curdate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 379, line 379) (in query: SELECT curdate(NULL, NULL);) 2025.06.13 15:38:24.284874 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT curdate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:24.407345 [ 3931 ] {78ecb4b6-3953-4ffa-b155-1367c35b22c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT currentDatabase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 380, line 380) (in query: SELECT currentDatabase(NULL, NULL);) 2025.06.13 15:38:24.440343 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT currentDatabase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:24.594205 [ 3931 ] {74a93525-691f-4ce4-a886-3ba5fecefdf0} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 2, should be 0: In scope SELECT currentProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 381, line 381) (in query: SELECT currentProfiles(NULL, NULL);) 2025.06.13 15:38:24.596911 [ 8099 ] {38ee7189-44e1-4fb5-9784-36b6110cd11c} executeQuery: Code: 36. DB::Exception: You must provide an ORDER BY or PRIMARY KEY expression in the table definition. If you don't want this table to be sorted, use ORDER BY/PRIMARY KEY (). Otherwise, you can use the setting 'create_table_empty_primary_key_by_default' to automatically add an empty primary key to the table definition. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51276) (comment: 02903_empty_order_by_throws_error.sh) (query 2, line 3) (in query: CREATE TABLE test_empty_order_by(a UInt8) ENGINE = MergeTree() SETTINGS index_granularity = 8192;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:655: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c03c5 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:24.617003 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 2, should be 0: In scope SELECT currentProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:24.625767 [ 8099 ] {} TCPHandler: Code: 36. DB::Exception: You must provide an ORDER BY or PRIMARY KEY expression in the table definition. If you don't want this table to be sorted, use ORDER BY/PRIMARY KEY (). Otherwise, you can use the setting 'create_table_empty_primary_key_by_default' to automatically add an empty primary key to the table definition. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:655: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c03c5 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:24.721029 [ 3931 ] {848870c1-ec3d-4b04-b538-d791c78033e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 2, should be 0: In scope SELECT currentQueryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 382, line 382) (in query: SELECT currentQueryID(NULL, NULL);) 2025.06.13 15:38:24.727855 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 2, should be 0: In scope SELECT currentQueryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:24.878503 [ 3931 ] {978c072a-ccaa-4090-a12c-b32e1339bfb7} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 2, should be 0: In scope SELECT currentRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 383, line 383) (in query: SELECT currentRoles(NULL, NULL);) 2025.06.13 15:38:24.889506 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 2, should be 0: In scope SELECT currentRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:25.055672 [ 3931 ] {cd78e7d4-6a64-47ee-82e4-afe6c15311b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT currentSchemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 384, line 384) (in query: SELECT currentSchemas(NULL, NULL);) 2025.06.13 15:38:25.066179 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT currentSchemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:25.290982 [ 3931 ] {879d2a2b-bd63-454d-99e0-e64d2d2e733a} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT currentUser(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 385, line 385) (in query: SELECT currentUser(NULL, NULL);) 2025.06.13 15:38:25.300719 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT currentUser(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:25.414686 [ 3931 ] {ebae8b27-4de5-476f-a991-7bc404fc1622} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT current_database(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 386, line 386) (in query: SELECT current_database(NULL, NULL);) 2025.06.13 15:38:25.444559 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT current_database(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:25.612968 [ 3931 ] {5da4133b-2c69-4ba0-a8ee-49b9bc9e351e} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT current_date(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 387, line 387) (in query: SELECT current_date(NULL, NULL);) 2025.06.13 15:38:25.627284 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT current_date(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:25.780226 [ 3931 ] {c69c6e34-d747-4a58-adc4-866767bacabf} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 2, should be 0: In scope SELECT current_query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 388, line 388) (in query: SELECT current_query_id(NULL, NULL);) 2025.06.13 15:38:25.794867 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 2, should be 0: In scope SELECT current_query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:25.887191 [ 3931 ] {809fde91-4e35-46bf-9981-f2e4cc20cb9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT current_schemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 389, line 389) (in query: SELECT current_schemas(NULL, NULL);) 2025.06.13 15:38:25.908528 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT current_schemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:26.042342 [ 3931 ] {30563b6b-7aa4-46e7-a89e-049ce15b7b23} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 390, line 390) (in query: SELECT current_timestamp(NULL, NULL);) 2025.06.13 15:38:26.067367 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:26.167425 [ 3931 ] {37db42d6-be65-4724-b788-7c465229a560} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT current_user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 391, line 391) (in query: SELECT current_user(NULL, NULL);) 2025.06.13 15:38:26.175165 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT current_user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:26.321427 [ 3931 ] {9497e1c8-ab58-4829-86a4-47848fe85c57} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 2, should be 1: In scope SELECT cutFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 392, line 392) (in query: SELECT cutFragment(NULL, NULL);) 2025.06.13 15:38:26.338829 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 2, should be 1: In scope SELECT cutFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:26.387514 [ 9643 ] {1b530f21-0dd4-4aec-9bf0-86fee30b5e9e} executeQuery: Code: 169. DB::Exception: is_deleted column (is_deleted) for storage ReplacingMergeTree must have type UInt8. Provided column of type UInt16. (BAD_TYPE_OF_FIELD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 1, line 1) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` Int64, `is_deleted` UInt16) ENGINE = ReplacingMergeTree(ver, is_deleted) ORDER BY key SETTINGS index_granularity = 54975, 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 = 381070958, compact_parts_max_granules_to_buffer = 213, compact_parts_merge_max_bytes_to_prefetch_part = 7052193, merge_max_block_size = 20516, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3733545323, index_granularity_bytes = 6021837, 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 = 64312, primary_key_compress_block_size = 53872, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c7f48af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1185: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c72aca 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:26.404204 [ 9643 ] {} TCPHandler: Code: 169. DB::Exception: is_deleted column (is_deleted) for storage ReplacingMergeTree must have type UInt8. Provided column of type UInt16. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c7f48af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1185: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c72aca 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:26.551247 [ 3931 ] {cc1c40fd-f3ec-47b1-baa9-ef35acd46899} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 2, should be 3: In scope SELECT cutIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 393, line 393) (in query: SELECT cutIPv6(NULL, NULL);) 2025.06.13 15:38:26.570501 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 2, should be 3: In scope SELECT cutIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:26.674341 [ 9643 ] {d4c9ad05-8500-411d-b359-41aec42229ca} executeQuery: Code: 169. DB::Exception: The column ver cannot be used as a version column for storage ReplacingMergeTree because it is of type String (must be of an integer type or of type Date/DateTime/DateTime64). (BAD_TYPE_OF_FIELD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 2, line 2) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` String, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(ver, is_deleted) ORDER BY key SETTINGS index_granularity = 54975, 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 = 381070958, compact_parts_max_granules_to_buffer = 213, compact_parts_merge_max_bytes_to_prefetch_part = 7052193, merge_max_block_size = 20516, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3733545323, index_granularity_bytes = 6021837, 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 = 64312, primary_key_compress_block_size = 53872, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c7f48af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1152: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_2::operator()(bool, String const&) const @ 0x0000000030c7e7c7 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1243: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7220b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:38:26.699984 [ 9643 ] {} TCPHandler: Code: 169. DB::Exception: The column ver cannot be used as a version column for storage ReplacingMergeTree because it is of type String (must be of an integer type or of type Date/DateTime/DateTime64). (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c7f48af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1152: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_2::operator()(bool, String const&) const @ 0x0000000030c7e7c7 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1243: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c7220b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:38:26.852253 [ 3931 ] {057c02d7-8592-4cd0-9e33-ec306a8df176} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 2, should be 1: In scope SELECT cutQueryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 394, line 394) (in query: SELECT cutQueryString(NULL, NULL);) 2025.06.13 15:38:26.870522 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 2, should be 1: In scope SELECT cutQueryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:27.232763 [ 9643 ] {f191444a-c269-4f8a-8cd9-861ff57c8441} executeQuery: Code: 36. DB::Exception: The version and is_deleted column cannot be the same column (is_deleted). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 3, line 3) (in query: CREATE TABLE replacing_wrong (`key` Int64, `ver` Int64, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(is_deleted, is_deleted) ORDER BY key SETTINGS index_granularity = 54975, 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 = 381070958, compact_parts_max_granules_to_buffer = 213, compact_parts_merge_max_bytes_to_prefetch_part = 7052193, merge_max_block_size = 20516, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3733545323, index_granularity_bytes = 6021837, 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 = 64312, primary_key_compress_block_size = 53872, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1240: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c72449 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:27.245074 [ 3931 ] {4dd7aa74-cb33-4d12-92ed-75e10482c3ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 395, line 395) (in query: SELECT cutQueryStringAndFragment(NULL, NULL);) 2025.06.13 15:38:27.293362 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:27.297315 [ 9643 ] {} TCPHandler: Code: 36. DB::Exception: The version and is_deleted column cannot be the same column (is_deleted). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1240: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c72449 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:27.494154 [ 3931 ] {d960d273-cf81-4b5f-a892-add7dda51d6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 396, line 396) (in query: SELECT cutToFirstSignificantSubdomain(NULL, NULL);) 2025.06.13 15:38:27.518014 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:28.144264 [ 9643 ] {444c3e09-a86a-436f-87b3-7a87e788ba03} executeQuery: Code: 524. DB::Exception: Cannot alter version column ver to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 5, line 6) (in query: ALTER TABLE replacing MODIFY COLUMN ver String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3468: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccb970 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:38:28.159353 [ 9643 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column ver to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3468: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccb970 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:38:28.233748 [ 6956 ] {} DDLWorker(rdb_test_15_2): Error on initialization of rdb_test_15_2: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:28.721216 [ 9643 ] {cfbad371-38a4-4d0b-9407-e63d937350ec} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 7, line 8) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d8c90f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2df6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:28.753242 [ 9643 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d8c90f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2df6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:28.755643 [ 3931 ] {2add408c-2f57-4295-b18b-aaf579d01424} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 401, line 401) (in query: SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL);) 2025.06.13 15:38:28.790317 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:28.880740 [ 9643 ] {fc1ee62d-db47-457f-80fb-e3de7f802d1b} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type UInt16, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 8, line 9) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted UInt16;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d8c90f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2df6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:28.893022 [ 9643 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type UInt16, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d8c90f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2df6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:28.905230 [ 3931 ] {43bf19aa-e99c-43e5-94b0-5cee3380b53b} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 402, line 402) (in query: SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL);) 2025.06.13 15:38:28.913721 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:29.144140 [ 3931 ] {a623bce0-ced4-470c-bf18-f78c8b613894} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 403, line 403) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL);) 2025.06.13 15:38:29.168049 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:29.170102 [ 9643 ] {7bd61156-5eed-4dcf-a25a-502bab9b668d} executeQuery: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type Int8, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 9, line 10) (in query: ALTER TABLE replacing MODIFY COLUMN is_deleted Int8;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d8c90f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2df6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:29.199133 [ 9643 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter is_deleted column (is_deleted) to type Int8, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d8c90f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2df6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:29.407413 [ 9643 ] {0144050d-90e7-4f68-aa28-4491c592a327} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 10, line 11) (in query: ALTER TABLE replacing DROP COLUMN ver;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3667: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccb85c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:38:29.444324 [ 9643 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3667: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccb85c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:38:29.570754 [ 3931 ] {0565e472-912e-4249-94b0-60af51d4a235} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 2, should be 1: In scope SELECT cutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 405, line 405) (in query: SELECT cutWWW(NULL, NULL);) 2025.06.13 15:38:29.580762 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 2, should be 1: In scope SELECT cutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:29.605713 [ 3895 ] {24e3d4da-58b2-4c04-9a97-118b63b0ec9e} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_15/rdb/log/query-0000000019 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.331920613 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51342) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: delete from rdb_test_15.mt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df0acf7 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6190db 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:38:29.616776 [ 8442 ] {7f021aa9-b0de-498c-a112-329a4833b61c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=0): While reading or decompressing /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_9_9_0/value.bin (position: 2892792, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 7e7a45e01889726d35df4633b255a579823686000000200100): (while reading column value): (while reading from part /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_9_9_0/ in table test_9no4963l.num_1 (6f369f7e-96d3-4de1-8c66-917a3aff8b5b) located on disk default of type local, from mark 77 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51414) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (query 1, line 2) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2) r on l.key = r.key order by l.key limit 10 offset 700000 SETTINGS allow_experimental_analyzer=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032da3168 17. DB::ReadBuffer::next() @ 0x0000000017e74832 18. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002c66dc72 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 30. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 2025.06.13 15:38:29.625824 [ 3895 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_15/rdb/log/query-0000000019 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.331920613 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df0acf7 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6190db 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:29.627872 [ 9643 ] {8649a57b-161f-4f1e-b92a-b9d2e790ebd2} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 11, line 12) (in query: ALTER TABLE replacing DROP COLUMN is_deleted;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d8c98f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2e66 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:29.647417 [ 9643 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d8c98f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2e66 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:29.770412 [ 9643 ] {b5325d33-540c-4b79-9339-1ce22d4ffc7c} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 12, line 13) (in query: ALTER TABLE replacing RENAME COLUMN ver TO ver2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3672: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccb79b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:38:29.794505 [ 9643 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME version ver column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3672: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccb79b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:38:29.865522 [ 8442 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=0): While reading or decompressing /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_9_9_0/value.bin (position: 2892792, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 7e7a45e01889726d35df4633b255a579823686000000200100): (while reading column value): (while reading from part /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_9_9_0/ in table test_9no4963l.num_1 (6f369f7e-96d3-4de1-8c66-917a3aff8b5b) located on disk default of type local, from mark 77 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032da3168 17. DB::ReadBuffer::next() @ 0x0000000017e74832 18. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002c66dc72 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 30. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:29.994103 [ 9643 ] {31c71359-17df-438c-a40e-55df672df6e5} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 13, line 14) (in query: ALTER TABLE replacing RENAME COLUMN is_deleted TO is_deleted2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d8c98f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2ed6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:30.018876 [ 9643 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME is_deleted (is_deleted) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d8c98f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2ed6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:30.088931 [ 8099 ] {4cc51071-1c2c-4635-967f-c6951bb3af9d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=3): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51310) (comment: 00872_t64_bit_codec.sql) (query 10, line 24) (in query: SELECT * FROM t64 WHERE u16 != t_u16;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f585dc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f5af07 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 13. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c660da5 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f54898 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f54302 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dd53bf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dcd2b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e828f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003221c43f 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 2025.06.13 15:38:30.144328 [ 8099 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=3): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f585dc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f5af07 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 13. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c660da5 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f54898 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f54302 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dd53bf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dcd2b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e828f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003221c43f 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:30.218555 [ 5163 ] {07aecac4-6225-4f7e-9408-8ad7be1d4a59} 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.20286.altinityantalya (altinity build)) (from [::1]:51508) (comment: 02888_system_tables_with_inaccessible_table_function.sql) (query 1, line 3) (in query: DROP DATABASE IF EXISTS test_5), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:448: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcab9c2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:38:30.289392 [ 5163 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:448: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcab9c2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:38:30.350787 [ 9643 ] {f0716176-2bbf-4d34-8832-588a6b4130a6} executeQuery: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type Int16. (BAD_TYPE_OF_FIELD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 14, line 16) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` Int16) ENGINE = CollapsingMergeTree(sign) ORDER BY key SETTINGS index_granularity = 54975, 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 = 381070958, compact_parts_max_granules_to_buffer = 213, compact_parts_merge_max_bytes_to_prefetch_part = 7052193, merge_max_block_size = 20516, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3733545323, index_granularity_bytes = 6021837, 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 = 64312, primary_key_compress_block_size = 53872, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c7f48af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1125: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c7e488 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c71c41 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:38:30.370449 [ 9643 ] {} TCPHandler: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type Int16. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c7f48af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1125: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c7e488 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c71c41 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:38:30.395615 [ 3931 ] {ec1edbb1-c33d-4396-95e9-12cd282c1db0} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 409, line 409) (in query: SELECT dateTime64ToSnowflake(NULL, NULL);) 2025.06.13 15:38:30.453882 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:30.561598 [ 9643 ] {42b1d1bf-e34f-4f10-9830-dbdeae3f0aca} executeQuery: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type UInt8. (BAD_TYPE_OF_FIELD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 15, line 17) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` UInt8) ENGINE = CollapsingMergeTree(sign) ORDER BY key SETTINGS index_granularity = 54975, 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 = 381070958, compact_parts_max_granules_to_buffer = 213, compact_parts_merge_max_bytes_to_prefetch_part = 7052193, merge_max_block_size = 20516, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3733545323, index_granularity_bytes = 6021837, 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 = 64312, primary_key_compress_block_size = 53872, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c7f48af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1125: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c7e488 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c71c41 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:38:30.573011 [ 9643 ] {} TCPHandler: Code: 169. DB::Exception: Sign column (sign) for storage CollapsingMergeTree must have type Int8. Provided column of type UInt8. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&&) @ 0x000000002c7f48af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1125: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c7e488 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c71c41 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:38:30.606706 [ 3931 ] {e53f4cea-1c0c-4c82-915a-bb1cafb47fe4} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 411, line 411) (in query: SELECT dateTimeToSnowflake(NULL, NULL);) 2025.06.13 15:38:30.618810 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:30.752424 [ 9643 ] {e0201510-1d7c-4da2-9f4b-6bc5fd650990} executeQuery: Code: 16. DB::Exception: Sign column not_existing does not exist in table declaration. (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 16, line 18) (in query: CREATE TABLE collapsing_wrong (`key` Int64, `sign` UInt8) ENGINE = CollapsingMergeTree(not_existing) ORDER BY key SETTINGS index_granularity = 54975, 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 = 381070958, compact_parts_max_granules_to_buffer = 213, compact_parts_merge_max_bytes_to_prefetch_part = 7052193, merge_max_block_size = 20516, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3733545323, index_granularity_bytes = 6021837, 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 = 64312, primary_key_compress_block_size = 53872, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1132: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c7e36e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c71c41 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:38:30.762425 [ 9643 ] {} TCPHandler: Code: 16. DB::Exception: Sign column not_existing does not exist in table declaration. (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1132: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const::$_1::operator()(bool, String const&) const @ 0x0000000030c7e36e 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1198: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c71c41 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:38:30.866145 [ 5163 ] {7e6a7021-bb7f-4374-9c60-343ad5c7b1cf} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51572) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 2, line 2) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(SEMI, ALL, a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:30.884210 [ 5163 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:30.995483 [ 4172 ] {475311de-5a81-4423-a7f4-630ff1dfe325} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness RightAny. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51576) (comment: 00555_right_join_excessive_rows.sql) (query 3, line 3) (in query: SELECT * FROM (select toUInt64(1) s limit 1) js1 any right join (select number s, s as x from numbers(11)) js2 using (s) ORDER BY s;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x0000000031dec10f 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:446: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x0000000031ddce14 6. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x0000000031ddd561 7. ./src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x0000000031deb2b4 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::vector>&, DB::Block const&, unsigned long&, std::allocator, 0>(std::allocator, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3a1eda 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, 0>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3a1cee 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002c395a69 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000032129489 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.021357 [ 4172 ] {} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness RightAny. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x0000000031dec10f 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:446: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x0000000031ddce14 6. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:470: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x0000000031ddd561 7. ./src/Processors/Merges/IMergingTransform.h:112: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x0000000031deb2b4 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::vector>&, DB::Block const&, unsigned long&, std::allocator, 0>(std::allocator, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3a1eda 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&, 0>(std::allocator const&, std::shared_ptr&, std::vector>&, DB::Block const&, unsigned long&) @ 0x000000002c3a1cee 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002c395a69 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:114: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000032129489 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.026902 [ 5163 ] {4777ddd3-e714-47d0-8bbe-571d4e566e99} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51572) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 3, line 8) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(SEMI, INNER, a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.067549 [ 5163 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.226993 [ 5163 ] {1d10ac5e-aaa6-47c2-a446-b6b2cb5c99be} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51572) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 4, line 14) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(SEMI, FULL, a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.237653 [ 5163 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.247910 [ 9643 ] {ea5ee7cd-78a0-4a7d-99dd-31ccc1f25d32} executeQuery: Code: 524. DB::Exception: Cannot alter sign column (sign) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 18, line 21) (in query: ALTER TABLE collapsing MODIFY COLUMN sign String;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d8c90f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2df6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.253162 [ 9643 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter sign column (sign) to type String, because it must have type . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&, String, std::basic_string_view> const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type, std::type_identity::type, std::type_identity> const&>::type>, std::basic_string_view> const&, String const&, String&&, std::basic_string_view> const&) @ 0x0000000030d8c90f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1052: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2df6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.312781 [ 5163 ] {338a5f37-3eca-49bf-9499-3e5f207ed5d8} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51572) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 5, line 20) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANTI, ALL, a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.323217 [ 5163 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.357950 [ 9643 ] {1005887a-ff47-4895-8b42-31efb77f1a1d} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 19, line 22) (in query: ALTER TABLE collapsing DROP COLUMN sign;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d8c98f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2e66 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.375629 [ 9643 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d8c98f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1063: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2e66 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.481569 [ 5163 ] {5390df38-175d-487d-8ad2-ce00bd6d3409} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51572) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 6, line 26) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANTI, INNER, a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.492019 [ 5163 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.513563 [ 9643 ] {9bf587cc-53d0-44a7-a2da-a42103f3bd22} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 20, line 23) (in query: ALTER TABLE collapsing RENAME COLUMN sign TO sign2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d8c98f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2ed6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.521515 [ 9643 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME sign (sign) column. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String&&) @ 0x0000000030d8c98f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1071: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2ed6 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.611701 [ 5978 ] {2721d7ad-1c73-44d4-bdab-b9449d74559b} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage GenerateRandom. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51594) (comment: 01087_storage_generate.sql) (query 4, line 5) (in query: DROP TABLE IF EXISTS test_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.615201 [ 5163 ] {5df7ac2d-c3b3-43c9-830a-eae38f4912ee} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51572) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 7, line 32) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANTI, FULL, a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.626838 [ 5163 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.626951 [ 3931 ] {93107312-ed6a-4158-a808-3454151fadc1} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 416, line 416) (in query: SELECT decodeHTMLComponent(NULL, NULL);) 2025.06.13 15:38:31.659146 [ 5978 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage GenerateRandom. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.659376 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:31.735715 [ 9643 ] {c7f2ed2f-9e70-4252-aa50-0c9f42f2dbcc} executeQuery: Code: 524. DB::Exception: Trying to modify settings for column sign (sign) . (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 21, line 24) (in query: ALTER TABLE collapsing MODIFY COLUMN sign MODIFY SETTING max_compress_block_size = 123456;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String const&) @ 0x0000000030d8c88f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1044: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2cea 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.753481 [ 5163 ] {00499c6e-6cb1-45b1-a69d-00b13cc5b94d} executeQuery: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51572) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 8, line 38) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANY, FULL, a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:480: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f8a1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.756148 [ 9643 ] {} TCPHandler: Code: 524. DB::Exception: Trying to modify settings for column sign (sign) . (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception> const&, String const&>(int, FormatStringHelperImpl> const&>::type, std::type_identity::type>, std::basic_string_view> const&, String const&) @ 0x0000000030d8c88f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1044: void DB::(anonymous namespace)::checkSpecialColumn>(std::basic_string_view>, DB::AlterCommand const&) @ 0x0000000030cd2cea 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc8342 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.762485 [ 5163 ] {} TCPHandler: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:480: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f8a1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:31.827449 [ 3931 ] {e80d3f74-a56e-4878-89cf-704a22cac31c} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 417, line 417) (in query: SELECT decodeURLComponent(NULL, NULL);) 2025.06.13 15:38:31.849202 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:32.034216 [ 3931 ] {ad6e3429-e606-4e31-b6ed-41c44c876ac1} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 418, line 418) (in query: SELECT decodeURLFormComponent(NULL, NULL);) 2025.06.13 15:38:32.077169 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:32.126813 [ 9643 ] {4478fdb4-12b8-4245-9190-c3d3b42142a0} executeQuery: Code: 36. DB::Exception: The version and sign column cannot be the same column (sign). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51372) (comment: 03093_special_column_errors.sql) (query 22, line 26) (in query: CREATE TABLE versioned_collapsing_wrong (`key` Int64, `version` UInt8, `sign` Int8) ENGINE = VersionedCollapsingMergeTree(sign, sign) ORDER BY key SETTINGS index_granularity = 54975, 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 = 381070958, compact_parts_max_granules_to_buffer = 213, compact_parts_merge_max_bytes_to_prefetch_part = 7052193, merge_max_block_size = 20516, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3733545323, index_granularity_bytes = 6021837, 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 = 64312, primary_key_compress_block_size = 53872, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1249: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c724e4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:32.146263 [ 9643 ] {} TCPHandler: Code: 36. DB::Exception: The version and sign column cannot be the same column (sign). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1249: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x0000000030c724e4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:520: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f8a6 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:32.242721 [ 3931 ] {9429aa63-8852-4858-a701-5ebcdb62312d} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 419, line 419) (in query: SELECT decodeXMLComponent(NULL, NULL);) 2025.06.13 15:38:32.262148 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:32.528392 [ 3931 ] {5c65c8fc-72f5-4ec8-bb73-a8cfc86bbc34} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 2, should be 0: In scope SELECT defaultProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 421, line 421) (in query: SELECT defaultProfiles(NULL, NULL);) 2025.06.13 15:38:32.548413 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 2, should be 0: In scope SELECT defaultProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:32.778473 [ 3931 ] {623e4cff-08c8-42ed-985f-e8943a0856e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 2, should be 0: In scope SELECT defaultRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 422, line 422) (in query: SELECT defaultRoles(NULL, NULL);) 2025.06.13 15:38:32.787392 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 2, should be 0: In scope SELECT defaultRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:33.002966 [ 3931 ] {771a377f-11ce-4ee5-8ac3-cb3414ba1ba8} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 423, line 423) (in query: SELECT defaultValueOfArgumentType(NULL, NULL);) 2025.06.13 15:38:33.035850 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:33.152769 [ 3931 ] {1dd3340a-0fa3-4ae5-9702-ee32712048df} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 424, line 424) (in query: SELECT defaultValueOfTypeName(NULL, NULL);) 2025.06.13 15:38:33.163470 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:33.287449 [ 3931 ] {a7d0b1ef-e5f9-4957-87ba-2fe248f8ae4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 2, should be 1: In scope SELECT degrees(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 425, line 425) (in query: SELECT degrees(NULL, NULL);) 2025.06.13 15:38:33.306082 [ 6956 ] {} DDLWorker(rdb_test_15_2): Error on initialization of rdb_test_15_2: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:33.324991 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 2, should be 1: In scope SELECT degrees(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:33.496254 [ 3931 ] {49560dc1-a252-49bb-84b3-5897dc9c8724} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 426, line 426) (in query: SELECT deltaSum(NULL, NULL);) 2025.06.13 15:38:33.509495 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:33.622741 [ 3931 ] {a59f4500-aaf1-4d41-8298-a6154a77269c} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 427, line 427) (in query: SELECT deltaSumTimestamp(NULL, NULL);) 2025.06.13 15:38:33.633090 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:38:33.720365 [ 4930 ] {a495deb7-a780-4691-8384-2312858e849f} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49538) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:33.727189 [ 4930 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:33.757399 [ 3931 ] {64979ba6-77a3-4f43-8dc3-41de2a931fad} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 2, should be 1: In scope SELECT demangle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 428, line 428) (in query: SELECT demangle(NULL, NULL);) 2025.06.13 15:38:33.771308 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 2, should be 1: In scope SELECT demangle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:33.877408 [ 5112 ] {5a73a7b6-e89b-4075-9612-0c73f7e8b23c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=7): While reading or decompressing /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_3_3_0/value.bin (position: 1321265, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: b2fa9bc14e722dcb451331f21c6fdb19828d82000000000100): (while reading column value): (while reading from part /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_3_3_0/ in table test_9no4963l.num_1 (6f369f7e-96d3-4de1-8c66-917a3aff8b5b) located on disk default of type local, from mark 24 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:45358) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (query 1, line 2) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value`, `__table3`.`key` AS `r.key`, `__table3`.`value` AS `r.value` FROM (SELECT `__table2`.`key` AS `key`, `__table2`.`value` AS `value` FROM `test_9no4963l`.`num_1` AS `__table2`) AS `__table1` GLOBAL ALL INNER JOIN `_data_6258490424270475035_2846009093013214965` AS `__table3` ON `__table1`.`key` = `__table3`.`key` ORDER BY `__table1`.`key` ASC LIMIT _CAST(700000, 'UInt64'), _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032da3168 17. DB::ReadBuffer::next() @ 0x0000000017e74832 18. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002c66dc72 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 30. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 2025.06.13 15:38:33.975464 [ 5112 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=7): While reading or decompressing /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_3_3_0/value.bin (position: 1321265, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: b2fa9bc14e722dcb451331f21c6fdb19828d82000000000100): (while reading column value): (while reading from part /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_3_3_0/ in table test_9no4963l.num_1 (6f369f7e-96d3-4de1-8c66-917a3aff8b5b) located on disk default of type local, from mark 24 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032da3168 17. DB::ReadBuffer::next() @ 0x0000000017e74832 18. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002c66dc72 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 30. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:33.980870 [ 3931 ] {dafcfa85-ed88-4c6a-815f-1b0286ea570c} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 429, line 429) (in query: SELECT denseRank(NULL, NULL);) 2025.06.13 15:38:33.989569 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:38:34.055228 [ 5110 ] {bcb437d0-5898-4af3-bd23-4c3d4037d416} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=5): While reading or decompressing /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_7_7_0/key.bin (position: 4068193, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: a482d6ba1fcbeb484e6e5247caeae727821680000000000100): (while reading column key): (while reading from part /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_7_7_0/ in table test_9no4963l.num_1 (6f369f7e-96d3-4de1-8c66-917a3aff8b5b) located on disk default of type local, from mark 120 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:46544) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (query 1, line 2) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value`, `__table3`.`key` AS `r.key`, `__table3`.`value` AS `r.value` FROM (SELECT `__table2`.`key` AS `key`, `__table2`.`value` AS `value` FROM `test_9no4963l`.`num_1` AS `__table2`) AS `__table1` GLOBAL ALL INNER JOIN `_data_6258490424270475035_2846009093013214965` AS `__table3` ON `__table1`.`key` = `__table3`.`key` ORDER BY `__table1`.`key` ASC LIMIT _CAST(700000, 'UInt64'), _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032da5a52 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c5f80e3 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 2025.06.13 15:38:34.106260 [ 4171 ] {77be5461-f58a-4974-bbad-c1a6f5b395cb} executeQuery: Code: 252. DB::Exception: Too many parts (10 with average size of 171.00 B) in table 'test_9.too_many_parts (aca53d62-b895-4efa-987f-a759f108ef73)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51396) (comment: 01603_insert_select_too_many_parts.sql) (query 8, line 14) (in query: -- exception is thrown if threshold is exceeded on new INSERT. INSERT INTO too_many_parts SELECT * FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000030d6e4ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000030cf2baa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb2d2 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:38:34.121061 [ 4171 ] {} TCPHandler: Code: 252. DB::Exception: Too many parts (10 with average size of 171.00 B) in table 'test_9.too_many_parts (aca53d62-b895-4efa-987f-a759f108ef73)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000030d6e4ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000030cf2baa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb2d2 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:38:34.127624 [ 3931 ] {ece484b5-e401-4a9b-a96d-764996091ce9} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 430, line 430) (in query: SELECT dense_rank(NULL, NULL);) 2025.06.13 15:38:34.140254 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:38:34.188597 [ 8442 ] {0b8e0c29-6605-480e-b4f0-4daf8c42686f} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49564) (comment: 01047_no_alias_columns_with_table_aliases.sql) (query 2, line 2) (in query: CREATE TABLE requests (`event_time` DateTime, `event_date` Date MATERIALIZED toDate(event_time), `event_tm` DateTime ALIAS event_time) ENGINE = MergeTree ORDER BY event_time SETTINGS index_granularity = 40739, min_bytes_for_wide_part = 189451159, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 114, min_bytes_for_full_part_storage = 508217138, compact_parts_max_bytes_to_buffer = 284452064, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 22166439, merge_max_block_size = 2136, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 802963, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 2269193385, index_granularity_bytes = 27758385, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 39, 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 = 71648, primary_key_compress_block_size = 13644, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:34.230244 [ 8101 ] {e5405501-08ac-4bfe-ad0d-40ad436a8fc6} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=7): While reading or decompressing /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_3_3_0/value.bin (position: 1321265, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: b2fa9bc14e722dcb451331f21c6fdb19828d82000000000100): (while reading column value): (while reading from part /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_3_3_0/ in table test_9no4963l.num_1 (6f369f7e-96d3-4de1-8c66-917a3aff8b5b) located on disk default of type local, from mark 24 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032da3168 17. DB::ReadBuffer::next() @ 0x0000000017e74832 18. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002c66dc72 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 30. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51566) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (query 1, line 2) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2) r on l.key = r.key order by l.key limit 10 offset 700000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_prefer_local_join = 0, parallel_replicas_local_plan=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:38:34.229061 [ 8442 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:34.238003 [ 3931 ] {14863484-7717-4c17-8523-3aab0ebf4060} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 431, line 431) (in query: SELECT detectCharset(NULL, NULL);) 2025.06.13 15:38:34.242696 [ 5110 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=5): While reading or decompressing /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_7_7_0/key.bin (position: 4068193, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: a482d6ba1fcbeb484e6e5247caeae727821680000000000100): (while reading column key): (while reading from part /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_7_7_0/ in table test_9no4963l.num_1 (6f369f7e-96d3-4de1-8c66-917a3aff8b5b) located on disk default of type local, from mark 120 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032da5a52 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c5f80e3 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181b22b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:34.271388 [ 5110 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46544, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:34.274792 [ 8101 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=7): While reading or decompressing /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_3_3_0/value.bin (position: 1321265, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: b2fa9bc14e722dcb451331f21c6fdb19828d82000000000100): (while reading column value): (while reading from part /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_3_3_0/ in table test_9no4963l.num_1 (6f369f7e-96d3-4de1-8c66-917a3aff8b5b) located on disk default of type local, from mark 24 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032da3168 17. DB::ReadBuffer::next() @ 0x0000000017e74832 18. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002c66dc72 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 30. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:34.275557 [ 5110 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46544, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:34.279454 [ 3931 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:38:34.358318 [ 3931 ] {7b86ae7a-13d5-463a-ba79-b3f62d439180} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 432, line 432) (in query: SELECT detectLanguage(NULL, NULL);) 2025.06.13 15:38:34.364517 [ 3931 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:38:34.444525 [ 3931 ] {4ce0f0d7-bff9-4d3b-9c79-86c25dee2f70} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 433, line 433) (in query: SELECT detectLanguageMixed(NULL, NULL);) 2025.06.13 15:38:34.455188 [ 3931 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:38:34.567437 [ 3931 ] {fc0fd735-a226-4274-bc0b-3602b4b0b86b} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 434, line 434) (in query: SELECT detectLanguageUnknown(NULL, NULL);) 2025.06.13 15:38:34.578090 [ 3931 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:38:34.691132 [ 3931 ] {dd096b17-a265-4b54-9116-4f12f5e01fbb} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 435, line 435) (in query: SELECT detectProgrammingLanguage(NULL, NULL);) 2025.06.13 15:38:34.763962 [ 3931 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:38:34.824993 [ 3931 ] {ac957f32-c786-4bac-8914-6c837d0c235b} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 436, line 436) (in query: SELECT detectTonality(NULL, NULL);) 2025.06.13 15:38:34.862539 [ 3931 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:38:34.879533 [ 3296 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x000000002d5f8b30 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000002d5f92c1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:34.970202 [ 3931 ] {af9aa6d3-385c-469f-a9d2-8491dc63ac57} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 437, line 437) (in query: SELECT dictGet(NULL, NULL);) 2025.06.13 15:38:34.984358 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:35.012329 [ 8432 ] {6beeb3cf-df97-4333-ba81-8434cd0d688b} executeQuery: Code: 57. DB::Exception: Table test_3.t_map_03240 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51676) (comment: 03240_array_element_or_null_for_map.sql) (query 13, line 20) (in query: CREATE TABLE t_map_03240(s String, fs FixedString(3), m1 Map(String, String), m2 Map(FixedString(3), String)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:38:35.048041 [ 8432 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.t_map_03240 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:38:35.100013 [ 3931 ] {418b8c6b-37a4-40f9-b0d8-090cddd37d6e} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 438, line 438) (in query: SELECT dictGetAll(NULL, NULL);) 2025.06.13 15:38:35.109949 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:35.188979 [ 3931 ] {ed53e79d-aee0-4cdc-b9d1-4e664fa64f50} executeQuery: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetChildren(NULL, NULL). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 439, line 439) (in query: SELECT dictGetChildren(NULL, NULL);) 2025.06.13 15:38:35.202154 [ 3931 ] {} TCPHandler: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetChildren(NULL, NULL). (UNSUPPORTED_METHOD) 2025.06.13 15:38:35.347491 [ 3931 ] {9210da9b-bde3-4ae1-92f4-9e991f7dc510} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDate doesn't match: the function requires more arguments: In scope SELECT dictGetDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 440, line 440) (in query: SELECT dictGetDate(NULL, NULL);) 2025.06.13 15:38:35.361694 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDate doesn't match: the function requires more arguments: In scope SELECT dictGetDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:35.603605 [ 3931 ] {3b77eac4-fed5-4ca8-82bc-d906dad476ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 441, line 441) (in query: SELECT dictGetDateOrDefault(NULL, NULL);) 2025.06.13 15:38:35.620622 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:35.698734 [ 3931 ] {57fdb410-7f1b-4ad8-b990-a1622ff8a485} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateTime doesn't match: the function requires more arguments: In scope SELECT dictGetDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 442, line 442) (in query: SELECT dictGetDateTime(NULL, NULL);) 2025.06.13 15:38:35.704820 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateTime doesn't match: the function requires more arguments: In scope SELECT dictGetDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:35.785227 [ 3931 ] {f5f9bff8-6529-4f89-a36c-978a51dfeb07} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateTimeOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateTimeOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 443, line 443) (in query: SELECT dictGetDateTimeOrDefault(NULL, NULL);) 2025.06.13 15:38:35.805842 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateTimeOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateTimeOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:35.921193 [ 3931 ] {31bde5c4-74c6-4877-be72-1f0dd9a4c0c6} executeQuery: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 444, line 444) (in query: SELECT dictGetDescendants(NULL, NULL);) 2025.06.13 15:38:35.955273 [ 3931 ] {} TCPHandler: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL). (UNSUPPORTED_METHOD) 2025.06.13 15:38:36.113703 [ 3931 ] {6831d236-4278-4912-9215-dff3bcc9bae7} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 445, line 445) (in query: SELECT dictGetFloat32(NULL, NULL);) 2025.06.13 15:38:36.125769 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:36.157387 [ 4930 ] {8b0b91bb-9e6c-4ae6-b7fe-752fddd8e89e} executeQuery: Code: 59. DB::Exception: Illegal type Int128 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49604) (comment: 02473_prewhere_with_bigint.sql) (query 7, line 8) (in query: SELECT a FROM prewhere_int128 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000032269f67 6. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000030f7c961 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003218d285 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000030e3154a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1085: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000030e12b86 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:176: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000030e1287c 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000311ca854 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda115e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:38:36.175979 [ 4930 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type Int128 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000032269f67 6. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000030f7c961 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003218d285 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000030e3154a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1085: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000030e12b86 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:176: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000030e1287c 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000311ca854 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda115e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:38:36.319869 [ 3931 ] {db7cb9c8-b899-4b3b-9cc0-a353c88dff05} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 446, line 446) (in query: SELECT dictGetFloat32OrDefault(NULL, NULL);) 2025.06.13 15:38:36.331399 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:36.424212 [ 3931 ] {8c686eaa-ad89-454b-9dd9-199b573a6c67} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 447, line 447) (in query: SELECT dictGetFloat64(NULL, NULL);) 2025.06.13 15:38:36.429048 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:36.542357 [ 3931 ] {474af67a-35de-4a64-bd39-324b322e4545} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 448, line 448) (in query: SELECT dictGetFloat64OrDefault(NULL, NULL);) 2025.06.13 15:38:36.551770 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:36.565961 [ 3895 ] {671f00d2-8cc6-4c84-a43f-fb121fa30723} executeQuery: Code: 36. DB::Exception: Unsupported aggregate function count, supported functions are any,anyLast,min,max,sum,sumWithOverflow,groupBitAnd,groupBitOr,groupBitXor,sumMap,minMap,maxMap,groupArrayArray,groupArrayLastArray,groupUniqArrayArray,groupUniqArrayArrayMap,sumMappedArrays,minMappedArrays,maxMappedArrays. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51698) (comment: 01570_aggregator_combinator_simple_state.sql) (query 15, line 17) (in query: -- non-SimpleAggregateFunction with countSimpleState(number) as c select toTypeName(c), c from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/DataTypes/DataTypeCustomSimpleAggregateFunction.cpp:59: DB::DataTypeCustomSimpleAggregateFunction::checkSupportedFunctions(std::shared_ptr const&) @ 0x000000002c3fb422 6. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:32: DB::AggregateFunctionSimpleState::createResultType(std::shared_ptr const&, DB::Array const&) @ 0x000000002842f09f 7. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:23: DB::AggregateFunctionSimpleState::AggregateFunctionSimpleState(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002842eeac 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::vector, std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002848610b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028485eec 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorSimpleState::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028485e57 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4987 12. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1c67b 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1d936 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:38:36.572539 [ 3895 ] {} TCPHandler: Code: 36. DB::Exception: Unsupported aggregate function count, supported functions are any,anyLast,min,max,sum,sumWithOverflow,groupBitAnd,groupBitOr,groupBitXor,sumMap,minMap,maxMap,groupArrayArray,groupArrayLastArray,groupUniqArrayArray,groupUniqArrayArrayMap,sumMappedArrays,minMappedArrays,maxMappedArrays. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/DataTypes/DataTypeCustomSimpleAggregateFunction.cpp:59: DB::DataTypeCustomSimpleAggregateFunction::checkSupportedFunctions(std::shared_ptr const&) @ 0x000000002c3fb422 6. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:32: DB::AggregateFunctionSimpleState::createResultType(std::shared_ptr const&, DB::Array const&) @ 0x000000002842f09f 7. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:23: DB::AggregateFunctionSimpleState::AggregateFunctionSimpleState(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002842eeac 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::vector, std::allocator>> const&, DB::Array const&, std::allocator, 0>(std::allocator, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002848610b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028485eec 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorSimpleState::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028485e57 11. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4987 12. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1c67b 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1d936 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:38:36.723533 [ 5978 ] {80b80093-3223-48f9-9433-953834288cb1} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_15/rdb/log/query-0000000020 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.499922274 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51682) (comment: 02445_replicated_db_alter_partition.sh) (query 1, line 1) (in query: delete from rdb_test_15.mt where n=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df0acf7 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6190db 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:38:36.770439 [ 5978 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_15/rdb/log/query-0000000020 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 3.499922274 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x000000002df0acf7 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x000000002d6190db 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:36.875627 [ 3931 ] {b71052a6-46fa-45ae-9039-93a02b418d3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 450, line 450) (in query: SELECT dictGetIPv4(NULL, NULL);) 2025.06.13 15:38:36.891713 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:37.006048 [ 4930 ] {ebb850a7-b4be-428f-900c-b0b8b6fce95a} executeQuery: Code: 59. DB::Exception: Illegal type Int256 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49604) (comment: 02473_prewhere_with_bigint.sql) (query 11, line 13) (in query: SELECT a FROM prewhere_int256 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000032269f67 6. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000030f7c961 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003218d285 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000030e3154a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1085: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000030e12b86 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:176: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000030e1287c 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000311ca854 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda115e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:38:37.013665 [ 3931 ] {4d5bda51-19b8-4097-8d1d-628108d064d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 451, line 451) (in query: SELECT dictGetIPv4OrDefault(NULL, NULL);) 2025.06.13 15:38:37.017499 [ 4930 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type Int256 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000032269f67 6. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000030f7c961 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003218d285 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000030e3154a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1085: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000030e12b86 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:176: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000030e1287c 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000311ca854 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda115e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:38:37.033858 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:37.175048 [ 3931 ] {52c7d081-2a4d-499d-9322-96fc0f7eae89} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 452, line 452) (in query: SELECT dictGetIPv6(NULL, NULL);) 2025.06.13 15:38:37.179476 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:37.239866 [ 3931 ] {f2474ebb-c466-4014-bf08-8ead3881efe1} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 453, line 453) (in query: SELECT dictGetIPv6OrDefault(NULL, NULL);) 2025.06.13 15:38:37.240350 [ 7755 ] {5349106c-a9b8-4ba1-bda9-ce4568a34868} executeQuery: Code: 57. DB::Exception: Table test_7.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49722) (comment: 03201_variant_null_map_subcolumn.sh) (query 1, line 1) (in query: CREATE TABLE test (`id` UInt64, `v` Variant(UInt64, Array(Variant(String, UInt64)))) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity = 54096, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 99, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 375386740, compact_parts_max_granules_to_buffer = 147, compact_parts_merge_max_bytes_to_prefetch_part = 13834701, merge_max_block_size = 1689, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 3501465627, vertical_merge_algorithm_min_rows_to_activate = 437518, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 9279305, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 30, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 81564, primary_key_compress_block_size = 93748, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:38:37.247853 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:37.267600 [ 7755 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:38:37.451338 [ 3931 ] {38a8453b-8485-4e6b-ad1c-140250a2cc59} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 454, line 454) (in query: SELECT dictGetInt16(NULL, NULL);) 2025.06.13 15:38:37.475093 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:37.569515 [ 3931 ] {1c22451b-d99d-4d40-8fcf-25709d813865} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 455, line 455) (in query: SELECT dictGetInt16OrDefault(NULL, NULL);) 2025.06.13 15:38:37.577223 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:37.719097 [ 3931 ] {575a10b7-2bb0-4378-b688-90bdebe7dcd5} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 456, line 456) (in query: SELECT dictGetInt32(NULL, NULL);) 2025.06.13 15:38:37.771942 [ 4930 ] {5137bda9-2ce6-4484-8e2f-eeffc9fbe447} executeQuery: Code: 59. DB::Exception: Illegal type UInt128 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49604) (comment: 02473_prewhere_with_bigint.sql) (query 15, line 18) (in query: SELECT a FROM prewhere_uint128 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000032269f67 6. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000030f7c961 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003218d285 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000030e3154a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1085: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000030e12b86 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:176: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000030e1287c 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000311ca854 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda115e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:38:37.781718 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:37.800463 [ 4930 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type UInt128 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000032269f67 6. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000030f7c961 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003218d285 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000030e3154a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1085: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000030e12b86 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:176: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000030e1287c 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000311ca854 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda115e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:38:37.935738 [ 3931 ] {64cc5a09-fd68-45e1-85f7-32bec22f0b1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 457, line 457) (in query: SELECT dictGetInt32OrDefault(NULL, NULL);) 2025.06.13 15:38:37.944708 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:37.980311 [ 4172 ] {ef4b0298-ad37-4b60-ae30-62a0bc5c6720} executeQuery: Code: 55. DB::Exception: Parametrized view can't be queried through a Merge table.: Child table: test_9.v (0c7d1a72-89c9-46ad-b28e-dd328e644e27). (STORAGE_REQUIRES_PARAMETER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49726) (comment: 03322_view_over_parameterized_view.sql) (query 3, line 3) (in query: select * from vv;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMerge.cpp:670: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x0000000030510b81 6. ./build_docker/./src/Storages/StorageMerge.cpp:596: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x00000000305092fd 7. ./build_docker/./src/Storages/StorageMerge.cpp:1624: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x000000003051f1a7 8. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000003228415c 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x0000000032283437 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280952 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:37.990319 [ 4172 ] {} TCPHandler: Code: 55. DB::Exception: Parametrized view can't be queried through a Merge table.: Child table: test_9.v (0c7d1a72-89c9-46ad-b28e-dd328e644e27). (STORAGE_REQUIRES_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMerge.cpp:670: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x0000000030510b81 6. ./build_docker/./src/Storages/StorageMerge.cpp:596: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x00000000305092fd 7. ./build_docker/./src/Storages/StorageMerge.cpp:1624: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x000000003051f1a7 8. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000003228415c 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x0000000032283437 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280952 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:38:38.105539 [ 3931 ] {4301a484-9326-47b6-a947-a139c293a7f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 458, line 458) (in query: SELECT dictGetInt64(NULL, NULL);) 2025.06.13 15:38:38.113591 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:38.301589 [ 3931 ] {400445c8-f639-489f-9c17-0e2d2c633dd5} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 459, line 459) (in query: SELECT dictGetInt64OrDefault(NULL, NULL);) 2025.06.13 15:38:38.313896 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:38.407594 [ 3931 ] {b14eb61f-753d-462f-82a3-d6a1acc88ae8} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 460, line 460) (in query: SELECT dictGetInt8(NULL, NULL);) 2025.06.13 15:38:38.425630 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:38.630160 [ 6956 ] {} DDLWorker(rdb_test_15_2): Error on initialization of rdb_test_15_2: Code: 57. DB::Exception: Directory for table data store/d55/d55c253f-ab35-4513-97ed-ba0333e32da6/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1486: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x000000002c78609d 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1492: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77d923 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:38.644001 [ 3931 ] {395fcc71-4f4a-4fd4-876f-f806fbaf3381} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 461, line 461) (in query: SELECT dictGetInt8OrDefault(NULL, NULL);) 2025.06.13 15:38:38.671077 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:38.861369 [ 3931 ] {db960c8a-7cc6-4326-9738-c622904a3a4b} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 462, line 462) (in query: SELECT dictGetOrDefault(NULL, NULL);) 2025.06.13 15:38:38.866185 [ 6219 ] {ddcd9de5-d33d-4e57-8a55-75a7f4e00c89} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=27, jobs=17): While reading or decompressing /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_8_8_0/key.bin (position: 1049577, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: e71dc8c0b2d255fac957d2d4e3402baa821780000000000100): (while reading column key): (while reading from part /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_8_8_0/ in table test_9no4963l.num_1 (6f369f7e-96d3-4de1-8c66-917a3aff8b5b) located on disk default of type local, from mark 24 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50358) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (query 1, line 2) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value`, `__table3`.`key` AS `r.key`, `__table3`.`value` AS `r.value` FROM (SELECT `__table2`.`key` AS `key`, `__table2`.`value` AS `value` FROM `test_9no4963l`.`num_1` AS `__table2`) AS `__table1` GLOBAL ALL INNER JOIN `_data_6258490424270475035_2846009093013214965` AS `__table3` ON `__table1`.`key` = `__table3`.`key` ORDER BY `__table1`.`key` ASC LIMIT _CAST(700000, 'UInt64'), _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032da5a52 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c5f80e3 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 2025.06.13 15:38:38.867481 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:38.957371 [ 3931 ] {23b4d6df-d4ee-44df-93cb-5c5b9545bffb} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 463, line 463) (in query: SELECT dictGetOrNull(NULL, NULL);) 2025.06.13 15:38:38.980527 [ 4930 ] {bba80429-de82-4b82-8805-8f7d947fe6e4} executeQuery: Code: 59. DB::Exception: Illegal type UInt256 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49604) (comment: 02473_prewhere_with_bigint.sql) (query 19, line 23) (in query: SELECT a FROM prewhere_uint256 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000032269f67 6. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000030f7c961 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003218d285 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000030e3154a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1085: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000030e12b86 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:176: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000030e1287c 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000311ca854 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda115e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:38:38.981399 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:38.990509 [ 4930 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type UInt256 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000032269f67 6. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000030f7c961 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003218d285 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000030e3154a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1085: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000030e12b86 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:176: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000030e1287c 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000311ca854 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda115e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:38:39.027092 [ 6219 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=27, jobs=17): While reading or decompressing /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_8_8_0/key.bin (position: 1049577, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: e71dc8c0b2d255fac957d2d4e3402baa821780000000000100): (while reading column key): (while reading from part /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_8_8_0/ in table test_9no4963l.num_1 (6f369f7e-96d3-4de1-8c66-917a3aff8b5b) located on disk default of type local, from mark 24 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032da5a52 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c5f80e3 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181b22b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:39.179466 [ 9644 ] {4b1d85cc-ceda-4c88-a953-998100924ab8} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=27, jobs=17): While reading or decompressing /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_8_8_0/key.bin (position: 1049577, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: e71dc8c0b2d255fac957d2d4e3402baa821780000000000100): (while reading column key): (while reading from part /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_8_8_0/ in table test_9no4963l.num_1 (6f369f7e-96d3-4de1-8c66-917a3aff8b5b) located on disk default of type local, from mark 24 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032da5a52 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c5f80e3 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181b22b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49612) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (query 1, line 2) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2) r on l.key = r.key order by l.key limit 10 offset 700000 SETTINGS enable_analyzer=1, send_logs_level='trace', enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_prefer_local_join = 0, parallel_replicas_local_plan=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:38:39.189824 [ 3931 ] {b21c4ba5-15b6-4729-9210-f96576805e63} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetString doesn't match: the function requires more arguments: In scope SELECT dictGetString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 464, line 464) (in query: SELECT dictGetString(NULL, NULL);) 2025.06.13 15:38:39.204123 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetString doesn't match: the function requires more arguments: In scope SELECT dictGetString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:39.209227 [ 9644 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=27, jobs=17): While reading or decompressing /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_8_8_0/key.bin (position: 1049577, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: e71dc8c0b2d255fac957d2d4e3402baa821780000000000100): (while reading column key): (while reading from part /var/lib/clickhouse/store/6f3/6f369f7e-96d3-4de1-8c66-917a3aff8b5b/all_8_8_0/ in table test_9no4963l.num_1 (6f369f7e-96d3-4de1-8c66-917a3aff8b5b) located on disk default of type local, from mark 24 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032da5a52 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c5f80e3 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181b22b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:39.329740 [ 3931 ] {69adfd4c-3238-4c8e-870e-13e8b55d014f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetStringOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetStringOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 465, line 465) (in query: SELECT dictGetStringOrDefault(NULL, NULL);) 2025.06.13 15:38:39.347838 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetStringOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetStringOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:39.376352 [ 3894 ] {ef7e7b1e-f453-423a-a9d6-c6de22239f58} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:42384). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316ba300 7. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x00000000316a4b63 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:39.431577 [ 3931 ] {34115f3f-ff73-43be-b362-b0b479fbd0af} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 466, line 466) (in query: SELECT dictGetUInt16(NULL, NULL);) 2025.06.13 15:38:39.461823 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:39.586874 [ 3931 ] {b3a6b1c7-aa33-4633-9241-33482d536459} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 467, line 467) (in query: SELECT dictGetUInt16OrDefault(NULL, NULL);) 2025.06.13 15:38:39.596838 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:39.719163 [ 3931 ] {80c97f41-0249-4998-8ff6-39383048f07a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 468, line 468) (in query: SELECT dictGetUInt32(NULL, NULL);) 2025.06.13 15:38:39.727689 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:39.853570 [ 3931 ] {00b6791d-6f4c-4b41-a659-969efa974188} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 469, line 469) (in query: SELECT dictGetUInt32OrDefault(NULL, NULL);) 2025.06.13 15:38:39.863526 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:39.989940 [ 3931 ] {e06db8b7-dfb8-4d22-b33c-3530627a2881} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 470, line 470) (in query: SELECT dictGetUInt64(NULL, NULL);) 2025.06.13 15:38:39.995746 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:40.078253 [ 3931 ] {1fadefab-6999-488a-ac08-354dec380b31} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 471, line 471) (in query: SELECT dictGetUInt64OrDefault(NULL, NULL);) 2025.06.13 15:38:40.092620 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:40.234050 [ 3931 ] {d29120f6-8ce9-47d1-a5fd-084bbf3885b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 472, line 472) (in query: SELECT dictGetUInt8(NULL, NULL);) 2025.06.13 15:38:40.243692 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:40.308534 [ 3931 ] {4e6010b5-f807-4f20-8e1f-85e9297154d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 473, line 473) (in query: SELECT dictGetUInt8OrDefault(NULL, NULL);) 2025.06.13 15:38:40.316444 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:40.397101 [ 3931 ] {4099eb6f-5cd2-4b05-b183-b7415e67558e} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUUID doesn't match: the function requires more arguments: In scope SELECT dictGetUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 474, line 474) (in query: SELECT dictGetUUID(NULL, NULL);) 2025.06.13 15:38:40.417613 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUUID doesn't match: the function requires more arguments: In scope SELECT dictGetUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:40.565294 [ 3931 ] {dad5d533-f606-469c-a67f-89f269214373} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUUIDOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUUIDOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 475, line 475) (in query: SELECT dictGetUUIDOrDefault(NULL, NULL);) 2025.06.13 15:38:40.575985 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUUIDOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUUIDOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:40.871447 [ 3931 ] {246fa0ac-df57-49cd-85fc-292bb8b088df} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 2, should be 3: In scope SELECT dictIsIn(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 477, line 477) (in query: SELECT dictIsIn(NULL, NULL);) 2025.06.13 15:38:40.892837 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 2, should be 3: In scope SELECT dictIsIn(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:40.966412 [ 6236 ] {633e91d6-47ec-4aa0-94ae-286735959255} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49748) (comment: 02311_hashed_array_dictionary_hierarchical_functions.gen.sql) (query 16, line 32) (in query: DROP DICTIONARY IF EXISTS hierarchy_hashed_array_dictionary;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:40.991108 [ 6236 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:41.037661 [ 3931 ] {3c27da9a-57ea-4a6c-8e12-b3d5042b0c70} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 2, should be 0: In scope SELECT displayName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 478, line 478) (in query: SELECT displayName(NULL, NULL);) 2025.06.13 15:38:41.058922 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 2, should be 0: In scope SELECT displayName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:41.729839 [ 3931 ] {815240cf-813f-4b6a-a1dc-c85dcf650c18} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT distanceLp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 483, line 483) (in query: SELECT distanceLp(NULL, NULL);) 2025.06.13 15:38:41.760523 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT distanceLp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:42.392173 [ 5110 ] {796cbd95-f8c9-41b6-9e77-61c4aaea8a09} DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc3b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db86a45 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002ddf7939 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002ddf774e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf40d6 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddaedfc 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: DB::(anonymous namespace)::buildQueryPlanForJoinNodeLegacy(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddac1bc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd98170 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:42.462078 [ 5110 ] {796cbd95-f8c9-41b6-9e77-61c4aaea8a09} 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.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50364) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (query 1, line 2) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value`, `__table3`.`key` AS `r.key`, `__table3`.`value` AS `r.value` FROM (SELECT `__table2`.`key` AS `key`, `__table2`.`value` AS `value` FROM `test_9no4963l`.`num_1` AS `__table2`) AS `__table1` GLOBAL ALL INNER JOIN `_data_6258490424270475035_2846009093013214965` AS `__table3` ON `__table1`.`key` = `__table3`.`key` ORDER BY `__table1`.`key` ASC LIMIT _CAST(700000, 'UInt64'), _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc3b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db86a45 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002ddf7939 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002ddf774e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf40d6 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddaedfc 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: DB::(anonymous namespace)::buildQueryPlanForJoinNodeLegacy(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddac1bc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd98170 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:38:42.490849 [ 5110 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc3b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db86a45 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002ddf7939 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002ddf774e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf40d6 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddaedfc 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: DB::(anonymous namespace)::buildQueryPlanForJoinNodeLegacy(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddac1bc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd98170 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:38:42.622831 [ 3895 ] {4fc3cb74-a9eb-43b7-9e98-ee69dd2ec907} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51368) (comment: 03158_dynamic_type_from_variant.sql) (in query: DROP DATABASE IF EXISTS test_30z2o4qa SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:42.627884 [ 8431 ] {ef28302a-f3ba-4b32-b866-701c4fa3231b} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc3b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db86a45 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002ddf7939 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002ddf774e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf40d6 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddaedfc 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: DB::(anonymous namespace)::buildQueryPlanForJoinNodeLegacy(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddac1bc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd98170 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49858) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (query 1, line 2) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2) r on l.key = r.key order by l.key limit 10 offset 700000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_prefer_local_join = 0, parallel_replicas_local_plan=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:38:42.701749 [ 3895 ] {4fc3cb74-a9eb-43b7-9e98-ee69dd2ec907} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:42.726175 [ 8431 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc3b16 7. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:170: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x000000002db86a45 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, std::allocator, 0>(std::allocator, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002ddf7939 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x000000002ddf774e 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf40d6 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1427: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddaedfc 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1966: DB::(anonymous namespace)::buildQueryPlanForJoinNodeLegacy(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddac1bc 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2057: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd98170 14. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:42.840650 [ 6219 ] {f1102bf0-d7a3-41a5-bfe7-e70cc54aed16} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51392) (comment: 03158_dynamic_type_from_variant.sql) (in query: DROP DATABASE IF EXISTS test_30z2o4qa SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:42.845799 [ 6219 ] {f1102bf0-d7a3-41a5-bfe7-e70cc54aed16} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:42.937800 [ 3931 ] {b56103af-1ca7-4a8f-a6f9-bab7ad3a5e53} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 2, should be 1: In scope SELECT domain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 489, line 489) (in query: SELECT domain(NULL, NULL);) 2025.06.13 15:38:42.965631 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 2, should be 1: In scope SELECT domain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:43.071468 [ 3931 ] {0216d6f0-ab58-4fa9-9bda-d0940394566e} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 2, should be 1: In scope SELECT domainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 490, line 490) (in query: SELECT domainRFC(NULL, NULL);) 2025.06.13 15:38:43.098150 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 2, should be 1: In scope SELECT domainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:43.207592 [ 3931 ] {f4ab632f-5046-4a6a-ac27-110104c7693c} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 491, line 491) (in query: SELECT domainWithoutWWW(NULL, NULL);) 2025.06.13 15:38:43.231689 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:43.408680 [ 3931 ] {60a60ae9-da96-482c-87eb-6525313b5df1} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 492, line 492) (in query: SELECT domainWithoutWWWRFC(NULL, NULL);) 2025.06.13 15:38:43.421384 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:43.648045 [ 3931 ] {cfac036e-cfa0-4984-aa56-31babf1fed9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 2, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 494, line 494) (in query: SELECT dumpColumnStructure(NULL, NULL);) 2025.06.13 15:38:43.658554 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 2, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:43.743537 [ 3931 ] {10d4baa6-e848-4895-81c2-987db518572e} executeQuery: Code: 43. DB::Exception: First argument for function dynamicElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT dynamicElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 495, line 495) (in query: SELECT dynamicElement(NULL, NULL);) 2025.06.13 15:38:43.752005 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function dynamicElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT dynamicElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:38:43.894794 [ 3931 ] {e108d158-91b4-47cc-80b3-39c9c890ab04} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 2, should be 1: In scope SELECT dynamicType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 496, line 496) (in query: SELECT dynamicType(NULL, NULL);) 2025.06.13 15:38:43.908613 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 2, should be 1: In scope SELECT dynamicType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:44.048225 [ 3931 ] {afdcc0f5-19a3-4de7-905b-300f11bbfb42} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 2, should be 0: In scope SELECT e(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 497, line 497) (in query: SELECT e(NULL, NULL);) 2025.06.13 15:38:44.150967 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 2, should be 0: In scope SELECT e(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:44.618120 [ 3931 ] {6d03dc95-7d90-463a-9385-eab6b092e3d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 2, should be 1: In scope SELECT empty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 500, line 500) (in query: SELECT empty(NULL, NULL);) 2025.06.13 15:38:44.626866 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 2, should be 1: In scope SELECT empty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:44.845798 [ 3931 ] {22f6d27f-5a3b-48f6-ab8c-6ddcb86453e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 501, line 501) (in query: SELECT emptyArrayDate(NULL, NULL);) 2025.06.13 15:38:44.871779 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:44.889244 [ 9642 ] {b64db163-c264-44a5-b722-71b72754794d} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40750) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 2, line 2) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(SEMI, ALL, a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:44.960200 [ 9642 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:45.044435 [ 3931 ] {952e252d-af76-4c83-b99c-5f27cca41947} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 502, line 502) (in query: SELECT emptyArrayDateTime(NULL, NULL);) 2025.06.13 15:38:45.068054 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:45.096135 [ 9642 ] {b669eadb-5f75-46e2-acc2-d3bdf6f67840} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40750) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 3, line 8) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(SEMI, INNER, a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:45.102656 [ 9642 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:45.230712 [ 9642 ] {6a41960b-92f2-4f3a-a031-795f77131fc2} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40750) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 4, line 14) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(SEMI, FULL, a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:45.232652 [ 3931 ] {6c6027d4-8d34-49c2-9936-54036207469c} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 503, line 503) (in query: SELECT emptyArrayFloat32(NULL, NULL);) 2025.06.13 15:38:45.247649 [ 9642 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:45.255727 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:45.369758 [ 3931 ] {ba85da05-79c2-4ecd-beef-140490a9272d} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 504, line 504) (in query: SELECT emptyArrayFloat64(NULL, NULL);) 2025.06.13 15:38:45.380632 [ 9642 ] {3cfd2f71-8c9d-4b16-b98e-3f8c93751c63} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40750) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 5, line 20) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANTI, ALL, a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:45.402303 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:45.416010 [ 9642 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:45.511899 [ 9642 ] {a165c166-5a73-43b7-9b17-6641d588b86a} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40750) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 6, line 26) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANTI, INNER, a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:45.529516 [ 9642 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:45.537287 [ 3931 ] {68887260-706c-4ead-8123-494dedd1b8a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 505, line 505) (in query: SELECT emptyArrayInt16(NULL, NULL);) 2025.06.13 15:38:45.545741 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:45.653181 [ 3931 ] {01194324-f33d-4fdb-bf0c-1e8e251db5fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 506, line 506) (in query: SELECT emptyArrayInt32(NULL, NULL);) 2025.06.13 15:38:45.655054 [ 9642 ] {520b1230-e290-4eb0-824e-f29f1bac5c00} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40750) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 7, line 32) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANTI, FULL, a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:45.671064 [ 9642 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:486: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f5fb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:45.682048 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:45.817752 [ 3931 ] {426a11ee-e422-4883-943a-5c45d74311b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 507, line 507) (in query: SELECT emptyArrayInt64(NULL, NULL);) 2025.06.13 15:38:45.839404 [ 9642 ] {9fb3a04e-461a-44ea-a74f-0faacf8ab893} executeQuery: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40750) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 8, line 38) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANY, FULL, a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:480: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f8a1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:45.905908 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:45.910810 [ 9642 ] {} TCPHandler: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:480: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003043f8a1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:46.030093 [ 3931 ] {c5743c3b-1c4a-464c-bc3a-869d82e8fc80} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 508, line 508) (in query: SELECT emptyArrayInt8(NULL, NULL);) 2025.06.13 15:38:46.044702 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:46.220579 [ 3931 ] {55abccaf-19d5-400b-bd6c-5a757f682e2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 2, should be 0: In scope SELECT emptyArrayString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 509, line 509) (in query: SELECT emptyArrayString(NULL, NULL);) 2025.06.13 15:38:46.255523 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 2, should be 0: In scope SELECT emptyArrayString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:46.445747 [ 3931 ] {47925711-867d-4d80-bd41-4e06ab8526c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 2, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 510, line 510) (in query: SELECT emptyArrayToSingle(NULL, NULL);) 2025.06.13 15:38:46.451379 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 2, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:46.615432 [ 3931 ] {2a0b787a-9729-4193-860d-025d60183df9} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 511, line 511) (in query: SELECT emptyArrayUInt16(NULL, NULL);) 2025.06.13 15:38:46.618799 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:46.873299 [ 3931 ] {468be36b-7b4f-48c4-b674-4fcd4d0c8c71} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 512, line 512) (in query: SELECT emptyArrayUInt32(NULL, NULL);) 2025.06.13 15:38:46.954830 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:47.196872 [ 3931 ] {f261190e-21a6-44ac-8807-7c5378c8c10e} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 513, line 513) (in query: SELECT emptyArrayUInt64(NULL, NULL);) 2025.06.13 15:38:47.272045 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:47.414070 [ 3931 ] {410d5656-0f00-4f2e-875b-486f3998f57d} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 514, line 514) (in query: SELECT emptyArrayUInt8(NULL, NULL);) 2025.06.13 15:38:47.492974 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:47.588121 [ 3931 ] {0363a848-bdc6-4743-89f8-375bbd48dbb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 2, should be 0: In scope SELECT enabledProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 515, line 515) (in query: SELECT enabledProfiles(NULL, NULL);) 2025.06.13 15:38:47.616205 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 2, should be 0: In scope SELECT enabledProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:47.693816 [ 3931 ] {e217f7f4-8386-4adf-9541-8e1820ecfae7} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 2, should be 0: In scope SELECT enabledRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 516, line 516) (in query: SELECT enabledRoles(NULL, NULL);) 2025.06.13 15:38:47.715108 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 2, should be 0: In scope SELECT enabledRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:47.843697 [ 3931 ] {552e9986-a550-4d5b-a764-178e082c4a34} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 517, line 517) (in query: SELECT encodeURLComponent(NULL, NULL);) 2025.06.13 15:38:47.857260 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:47.997919 [ 3931 ] {a54d901f-da13-4e97-bb8e-6833c73cdfdd} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 518, line 518) (in query: SELECT encodeURLFormComponent(NULL, NULL);) 2025.06.13 15:38:48.122196 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:48.260824 [ 3931 ] {f9ed894c-7283-4f54-8a0b-9f15b925a0f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 519, line 519) (in query: SELECT encodeXMLComponent(NULL, NULL);) 2025.06.13 15:38:48.280684 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:49.480472 [ 5112 ] {d8209353-8df7-4e0c-b30f-f7a143be619f} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40974) (comment: 02887_mutations_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:49.550278 [ 5112 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:49.709280 [ 3931 ] {3d323220-4e77-4e25-b5a6-805490f5f3a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 2, should be 1: In scope SELECT erf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 525, line 525) (in query: SELECT erf(NULL, NULL);) 2025.06.13 15:38:49.724173 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 2, should be 1: In scope SELECT erf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:49.874848 [ 3931 ] {6c9ae848-5257-4e12-a311-975cb6d7c50d} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 2, should be 1: In scope SELECT erfc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 526, line 526) (in query: SELECT erfc(NULL, NULL);) 2025.06.13 15:38:49.908991 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 2, should be 1: In scope SELECT erfc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:49.996829 [ 3931 ] {5cecd1ab-3da8-4b79-92dd-b715fdfc47f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 2, should be 1: In scope SELECT errorCodeToName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 527, line 527) (in query: SELECT errorCodeToName(NULL, NULL);) 2025.06.13 15:38:50.007123 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 2, should be 1: In scope SELECT errorCodeToName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:50.104371 [ 3931 ] {de4e01ab-ce7c-441a-ae9b-852782576eb6} executeQuery: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 528, line 528) (in query: SELECT estimateCompressionRatio(NULL, NULL);) 2025.06.13 15:38:50.117648 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:50.301561 [ 8099 ] {4ee1e0aa-138f-42ab-86b2-f22262ecf7e7} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40996) (comment: 03276_index_empty_part.sql) (query 2, line 3) (in query: CREATE TABLE t_index_empty_part (`c0` Int, `c1` Int) ENGINE = MergeTree PRIMARY KEY (c0, c1) SETTINGS primary_key_lazy_load = 0, remove_empty_parts = 0, index_granularity = 39429, min_bytes_for_wide_part = 856349488, ratio_of_defaults_for_sparse_serialization = 0.7182890176773071, replace_long_file_name_to_hash = true, max_file_name_length = 82, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 175863622, compact_parts_max_granules_to_buffer = 221, compact_parts_merge_max_bytes_to_prefetch_part = 15361975, merge_max_block_size = 14043, old_parts_lifetime = 460., 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 = 9148289510, index_granularity_bytes = 9456368, 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 = 13367, primary_key_compress_block_size = 47139, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:50.321168 [ 8099 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:50.399847 [ 3931 ] {2a659f0d-6c41-42e8-be0d-0b1a613dbea8} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 2, should be 1: In scope SELECT exp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 530, line 530) (in query: SELECT exp(NULL, NULL);) 2025.06.13 15:38:50.412203 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 2, should be 1: In scope SELECT exp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:50.573346 [ 3931 ] {5f49f7e4-0f76-4682-a076-896b986e8aa2} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 2, should be 1: In scope SELECT exp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 531, line 531) (in query: SELECT exp10(NULL, NULL);) 2025.06.13 15:38:50.597600 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 2, should be 1: In scope SELECT exp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:50.728345 [ 3931 ] {5f58ad02-2c89-4891-b0df-29550d6cb803} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 2, should be 1: In scope SELECT exp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 532, line 532) (in query: SELECT exp2(NULL, NULL);) 2025.06.13 15:38:50.734105 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 2, should be 1: In scope SELECT exp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:51.081952 [ 3931 ] {eef81fed-b8ef-4bb3-96f9-f8445c866a7e} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 534, line 534) (in query: SELECT exponentialTimeDecayedAvg(NULL, NULL);) 2025.06.13 15:38:51.095760 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:51.206355 [ 3931 ] {61c64759-5c61-4bed-a418-fe28789f9b58} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 535, line 535) (in query: SELECT exponentialTimeDecayedCount(NULL, NULL);) 2025.06.13 15:38:51.224903 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:51.356380 [ 3931 ] {723f29eb-86e8-462a-85b5-fba19c4ebe25} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 536, line 536) (in query: SELECT exponentialTimeDecayedMax(NULL, NULL);) 2025.06.13 15:38:51.373244 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:51.408900 [ 5163 ] {da1a6101-dcfb-4b44-a37f-ecd15bee1a54} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41082) (comment: 03143_parallel_replicas_mat_view_bug.sql) (query 5, line 7) (in query: CREATE TABLE null_table (str String) ENGINE = Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:51.424161 [ 5163 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:51.513626 [ 3931 ] {7bb1a159-067b-4bbc-89f3-e35cda864a9e} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 537, line 537) (in query: SELECT exponentialTimeDecayedSum(NULL, NULL);) 2025.06.13 15:38:51.532421 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:51.721565 [ 4172 ] {18b388f7-a188-44fd-bf88-ccb4b0584e20} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41164) (comment: 02530_dictionaries_update_field.sh) (query 1, line 1) (in query: DROP DICTIONARY dict_hashed_custom), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:51.780692 [ 4172 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:52.169166 [ 6236 ] {89256ebb-36cf-4ed4-840c-7e513ef4bdfa} executeQuery: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -1]). (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41156) (comment: 01777_map_populate_series_ubsan.sql) (query 1, line 1) (in query: -- Should correctly throw exception about overflow: SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -1]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x0000000023882ca6 6. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x0000000023881bac 7. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002364f53e 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:38:52.184780 [ 6236 ] {} TCPHandler: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -1]). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x0000000023882ca6 6. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x0000000023881bac 7. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002364f53e 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:38:52.979474 [ 7279 ] {f5a56959-a317-4a57-aea3-030655bb0a3e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40124) (comment: 00508_materialized_view_to.sql) (query 16, line 30) (in query: DROP DATABASE test_1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:53.029251 [ 7279 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:53.345506 [ 3931 ] {94714510-dfaa-49dc-ab85-4ff89e455730} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 2, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 546, line 546) (in query: SELECT extractTextFromHTML(NULL, NULL);) 2025.06.13 15:38:53.353719 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 2, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:53.621866 [ 3931 ] {a04b9160-8ea2-4bef-9d05-0b9b1163db90} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 2, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 548, line 548) (in query: SELECT extractURLParameterNames(NULL, NULL);) 2025.06.13 15:38:53.636836 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 2, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:53.827506 [ 3931 ] {b460a37c-c925-4d04-b38b-4bc861fe32a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 2, should be 1: In scope SELECT extractURLParameters(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 549, line 549) (in query: SELECT extractURLParameters(NULL, NULL);) 2025.06.13 15:38:53.834597 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 2, should be 1: In scope SELECT extractURLParameters(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:53.916689 [ 3931 ] {798c7688-940d-4bd0-b3b6-ddb305cee015} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 2, should be 1: In scope SELECT factorial(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 550, line 550) (in query: SELECT factorial(NULL, NULL);) 2025.06.13 15:38:53.940826 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 2, should be 1: In scope SELECT factorial(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:54.423890 [ 3931 ] {7da2b742-7642-42cf-89d5-8b7c7b5db6d6} executeQuery: Code: 48. DB::Exception: file is only implemented for type String: In scope SELECT file(NULL, NULL). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 553, line 553) (in query: SELECT file(NULL, NULL);) 2025.06.13 15:38:54.429586 [ 3931 ] {} TCPHandler: Code: 48. DB::Exception: file is only implemented for type String: In scope SELECT file(NULL, NULL). (NOT_IMPLEMENTED) 2025.06.13 15:38:54.602101 [ 9642 ] {3795f094-ecdf-46c3-bdeb-22c185dd9e67} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02782_inconsistent_formatting_and_constant_folding.sql) (in query: /* ddl_entry=query-0000000004 */ TRUNCATE TABLE test_kkqj6fyr.t7), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:38:54.710685 [ 9642 ] {3795f094-ecdf-46c3-bdeb-22c185dd9e67} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41144) (comment: 02782_inconsistent_formatting_and_constant_folding.sql) (query 9, line 40) (in query: DROP TABLE t7;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:38:54.736943 [ 9642 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:38:54.980432 [ 8099 ] {ce93d693-d467-4cd2-b76f-b758f6cb984b} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36034) (comment: 02782_inconsistent_formatting_and_constant_folding.sql) (in query: DROP DATABASE IF EXISTS test_kkqj6fyr SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:54.993523 [ 8099 ] {ce93d693-d467-4cd2-b76f-b758f6cb984b} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:55.036672 [ 3931 ] {bcdb7416-b80a-4037-a911-ab392e9a0da2} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 2, should be 1: In scope SELECT finalizeAggregation(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 557, line 557) (in query: SELECT finalizeAggregation(NULL, NULL);) 2025.06.13 15:38:55.052812 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 2, should be 1: In scope SELECT finalizeAggregation(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:55.126717 [ 9636 ] {f76be04c-d376-4541-9b95-82e7dacdece1} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47988) (comment: 01921_datatype_date32.sql) (query 2, line 2) (in query: create table t1(x1 Date32) engine Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:55.170883 [ 9636 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:55.251863 [ 3931 ] {f3c7f3e5-769a-424b-9059-544b9535ad7d} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 2, should be 1: In scope SELECT firstLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 558, line 558) (in query: SELECT firstLine(NULL, NULL);) 2025.06.13 15:38:55.268171 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 2, should be 1: In scope SELECT firstLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:55.311293 [ 6236 ] {d08e89cb-bdc0-4950-9150-725f948b18b8} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:8bb1c8b6-94d3-451e-80e1-69bc4684c62a'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36050) (comment: 03036_with_numbers.sql) (in query: CREATE DATABASE IF NOT EXISTS test_aehnkacf ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:55.318288 [ 6236 ] {d08e89cb-bdc0-4950-9150-725f948b18b8} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:8bb1c8b6-94d3-451e-80e1-69bc4684c62a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:55.366731 [ 3931 ] {2b2ee3bd-0a52-4c9b-8d9f-d531139cfe1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 559, line 559) (in query: SELECT firstSignificantSubdomain(NULL, NULL);) 2025.06.13 15:38:55.380261 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:55.485930 [ 5110 ] {d45d078c-216d-41ec-bb3d-ce23b3098fdf} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:7b368196-2ff5-47f2-bfb8-5bed5561da42'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36066) (comment: 02890_named_tuple_functions.sql) (in query: CREATE DATABASE IF NOT EXISTS test_e0139opk ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:55.498510 [ 5110 ] {d45d078c-216d-41ec-bb3d-ce23b3098fdf} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:7b368196-2ff5-47f2-bfb8-5bed5561da42'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:55.696647 [ 4107 ] {e9e77cac-0162-44c0-860e-01e6660472fb} executeQuery: Code: 190. DB::Exception: Array arguments for function arrayL1Distance must have equal sizes: In scope SELECT L1Distance([0, 0], [1]). (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40858) (comment: 02282_array_distance.sql) (query 36, line 97) (in query: SELECT L1Distance([0, 0], [1]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002114c4a9 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x000000002113dd20 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x000000002100eeeb 8. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002100d9c1 9. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d8d3bc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:38:55.708569 [ 4107 ] {} TCPHandler: Code: 190. DB::Exception: Array arguments for function arrayL1Distance must have equal sizes: In scope SELECT L1Distance([0, 0], [1]). (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002114c4a9 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x000000002113dd20 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x000000002100eeeb 8. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002100d9c1 9. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d8d3bc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:38:55.928736 [ 6236 ] {2d20f99c-11c0-4000-b74d-1c8cf15e97f4} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:1e0a49be-4e52-4f5f-b2f6-b29c07d6ba1e'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36072) (comment: 02457_insert_select_progress_http.sh) (in query: CREATE DATABASE IF NOT EXISTS test_ezb9fhd4 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:55.935306 [ 6236 ] {2d20f99c-11c0-4000-b74d-1c8cf15e97f4} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:1e0a49be-4e52-4f5f-b2f6-b29c07d6ba1e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:55.960191 [ 3931 ] {60cc2e9d-ddef-43e9-9703-11cc0299bd44} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 562, line 562) (in query: SELECT firstSignificantSubdomainRFC(NULL, NULL);) 2025.06.13 15:38:55.997493 [ 4107 ] {354a3adc-f01c-42a6-8fc0-2d567cd6efd4} executeQuery: Code: 43. DB::Exception: Argument 1 of function arrayL2Distance must be array.: In scope SELECT L2Distance([1, 2], (3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40858) (comment: 02282_array_distance.sql) (query 37, line 98) (in query: SELECT L2Distance([1, 2], (3,4));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb202f 5. DB::FunctionArrayDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000002126e7b2 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:38:55.999584 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:56.022896 [ 4107 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 of function arrayL2Distance must be array.: In scope SELECT L2Distance([1, 2], (3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb202f 5. DB::FunctionArrayDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000002126e7b2 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:38:56.133609 [ 8432 ] {af8858d2-9471-42aa-9f8c-36e50fd26e15} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:b2d78735-b8e9-43ca-9d81-2c95ac6f4fab'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36096) (comment: 02863_interpolate_subquery.sql) (in query: CREATE DATABASE IF NOT EXISTS test_xznpyyo5 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:56.148873 [ 8432 ] {af8858d2-9471-42aa-9f8c-36e50fd26e15} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:b2d78735-b8e9-43ca-9d81-2c95ac6f4fab'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:56.239087 [ 3931 ] {f60bae9e-0498-4c9d-9911-4aca853e9b0a} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 563, line 563) (in query: SELECT firstValueRespectNulls(NULL, NULL);) 2025.06.13 15:38:56.249196 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:56.290243 [ 4107 ] {ac9ee115-a1f1-4cb9-b549-36a7a4c41a9e} executeQuery: Code: 43. DB::Exception: Argument 1 of function arrayL2SquaredDistance must be array.: In scope SELECT L2SquaredDistance([1, 2], (3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40858) (comment: 02282_array_distance.sql) (query 38, line 99) (in query: SELECT L2SquaredDistance([1, 2], (3,4));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb202f 5. DB::FunctionArrayDistance::getReturnTypeImpl(std::vector> const&) const @ 0x00000000214c3f52 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:38:56.296802 [ 4107 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 of function arrayL2SquaredDistance must be array.: In scope SELECT L2SquaredDistance([1, 2], (3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb202f 5. DB::FunctionArrayDistance::getReturnTypeImpl(std::vector> const&) const @ 0x00000000214c3f52 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:38:56.399454 [ 5110 ] {0dd7422d-5e40-4659-94fa-c257abe8afce} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:16460476-8469-431b-8d30-4c8f8a2f2469'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36122) (comment: 03232_pr_not_ready_set.sql) (in query: CREATE DATABASE IF NOT EXISTS test_2vv406sy ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:56.405039 [ 5110 ] {0dd7422d-5e40-4659-94fa-c257abe8afce} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:16460476-8469-431b-8d30-4c8f8a2f2469'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:56.535167 [ 4107 ] {00cf072c-c087-49c4-a5d6-9a0a41d4eb74} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance([1, 2], [3, 4]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40858) (comment: 02282_array_distance.sql) (query 39, line 100) (in query: SELECT LpDistance([1, 2], [3,4]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:38:56.542830 [ 4107 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance([1, 2], [3, 4]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:38:56.576706 [ 3931 ] {4e58415d-a45f-4ac3-932c-875ac8e45994} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 565, line 565) (in query: SELECT first_value_respect_nulls(NULL, NULL);) 2025.06.13 15:38:56.603896 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:56.692815 [ 9636 ] {85b7eb10-b7fe-4de0-a10a-2c534053607d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:991d8809-a2e1-4f5e-9d6a-fe93cc40d16e'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36136) (comment: 01490_nullable_string_to_enum.sql) (in query: CREATE DATABASE IF NOT EXISTS test_g8z453f2 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:56.701684 [ 3931 ] {d0ad66ea-7865-4e0e-95de-8b360fd3d97f} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 566, line 566) (in query: SELECT flameGraph(NULL, NULL);) 2025.06.13 15:38:56.713820 [ 9636 ] {85b7eb10-b7fe-4de0-a10a-2c534053607d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:991d8809-a2e1-4f5e-9d6a-fe93cc40d16e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:56.718896 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:38:56.770267 [ 8101 ] {6eabbf6a-488c-49da-9c81-33c1a2cf98dc} executeQuery: Code: 57. DB::Exception: Table test_99rk8362.test1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01436_storage_merge_with_join_push_down.sql) (in query: /* ddl_entry=query-0000000006 */ CREATE TABLE test_99rk8362.test1 UUID 'cda66c83-d4ac-4e31-a843-da56e7da9ae8' (`id` Int64, `name` String) ENGINE = MergeTree PARTITION BY id ORDER BY id SETTINGS index_granularity = 64684, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.7530210018157959, 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 = 302497724, compact_parts_max_granules_to_buffer = 153, compact_parts_merge_max_bytes_to_prefetch_part = 17312576, merge_max_block_size = 13853, old_parts_lifetime = 348., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 7685788029, index_granularity_bytes = 22606564, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 85613, primary_key_compress_block_size = 58172, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:38:56.804307 [ 4107 ] {3d331426-46bc-4715-b4f1-9d7173ed1060} executeQuery: Code: 69. DB::Exception: Second argument for function arrayLpDistance must be not less than one and not be an infinity: In scope SELECT LpDistance([1, 2], [3, 4], -1.). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40858) (comment: 02282_array_distance.sql) (query 40, line 101) (in query: SELECT LpDistance([1, 2], [3,4], -1.);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x000000002100c617 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002184e536 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x0000000021840620 8. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x0000000021723d8b 9. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000217228c1 10. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d9943c 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:38:56.814050 [ 3894 ] {ccc4a404-6198-44ff-8563-09b4ed0927a1} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47920) (comment: 00508_materialized_view_to.sql) (query 14, line 27) (in query: DROP TABLE test_1.src), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:56.817602 [ 3931 ] {0e5cba28-1f71-4677-81fe-7d900769b319} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT flatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 567, line 567) (in query: SELECT flatten(NULL, NULL);) 2025.06.13 15:38:56.824565 [ 3894 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:38:56.835824 [ 8101 ] {6eabbf6a-488c-49da-9c81-33c1a2cf98dc} executeQuery: Code: 57. DB::Exception: Table test_99rk8362.test1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41198) (comment: 01436_storage_merge_with_join_push_down.sql) (query 11, line 20) (in query: CREATE TABLE test1 (`id` Int64, `name` String) ENGINE = MergeTree PARTITION BY id ORDER BY id SETTINGS index_granularity = 64684, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.7530210018157959, 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 = 302497724, compact_parts_max_granules_to_buffer = 153, compact_parts_merge_max_bytes_to_prefetch_part = 17312576, merge_max_block_size = 13853, old_parts_lifetime = 348., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 7685788029, index_granularity_bytes = 22606564, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 85613, primary_key_compress_block_size = 58172, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:38:56.839134 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT flatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:56.856490 [ 4107 ] {} TCPHandler: Code: 69. DB::Exception: Second argument for function arrayLpDistance must be not less than one and not be an infinity: In scope SELECT LpDistance([1, 2], [3, 4], -1.). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x000000002100c617 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002184e536 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x0000000021840620 8. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x0000000021723d8b 9. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000217228c1 10. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d9943c 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:38:56.860522 [ 8101 ] {} TCPHandler: Code: 57. DB::Exception: Table test_99rk8362.test1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:38:56.940393 [ 6236 ] {d8d6e6ed-2aa2-4448-b3e9-1972f86f0bc4} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:6d04a17b-bd9e-4061-bdbb-b58ac192b712'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36140) (comment: 02577_analyzer_array_join_calc_twice.sql) (in query: CREATE DATABASE IF NOT EXISTS test_t322rusm ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:56.942592 [ 6236 ] {d8d6e6ed-2aa2-4448-b3e9-1972f86f0bc4} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:6d04a17b-bd9e-4061-bdbb-b58ac192b712'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:56.942995 [ 3931 ] {dbff022e-1e54-4573-b253-44c1c13f8af7} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 2, should be 1: In scope SELECT flattenTuple(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 568, line 568) (in query: SELECT flattenTuple(NULL, NULL);) 2025.06.13 15:38:56.951345 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 2, should be 1: In scope SELECT flattenTuple(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:57.118466 [ 8099 ] {369ebe34-f6ff-440b-b1e3-7e7ca7e74fc4} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:3eaaaea5-5b9e-41dd-bef2-900aaa7f3923'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36156) (comment: 00836_indices_alter_replicated_zookeeper_long.sql) (in query: CREATE DATABASE IF NOT EXISTS test_6c4itfo5 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:57.131893 [ 8099 ] {369ebe34-f6ff-440b-b1e3-7e7ca7e74fc4} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:3eaaaea5-5b9e-41dd-bef2-900aaa7f3923'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:57.160596 [ 4107 ] {d0527fba-8d27-4ad7-9605-ddda2dcd96d9} executeQuery: Code: 43. DB::Exception: Argument p of function arrayLpDistance must be numeric constant: In scope SELECT LpDistance([1, 2], [3, 4], 'aaa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40858) (comment: 02282_array_distance.sql) (query 41, line 102) (in query: SELECT LpDistance([1, 2], [3,4], 'aaa');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x000000002100c507 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002184e536 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x0000000021840620 8. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x0000000021723d8b 9. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000217228c1 10. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d9943c 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:38:57.185358 [ 4107 ] {} TCPHandler: Code: 43. DB::Exception: Argument p of function arrayLpDistance must be numeric constant: In scope SELECT LpDistance([1, 2], [3, 4], 'aaa'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x000000002100c507 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002184e536 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x0000000021840620 8. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x0000000021723d8b 9. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000217228c1 10. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d9943c 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:38:57.380006 [ 4107 ] {de7b8e58-9e25-4a93-b4ef-7887d0b6c363} executeQuery: Code: 44. DB::Exception: Second argument for function arrayLpDistance must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40858) (comment: 02282_array_distance.sql) (query 42, line 103) (in query: SELECT LpDistance([1, 2], [3,4], materialize(2.7));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x000000002100c724 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithLeftArgConst(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002185a1c2 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002184dfcb 8. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x0000000021840620 9. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x0000000021723d8b 10. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000217228c1 11. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d9943c 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 20. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 22. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 23. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 24. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:38:57.408065 [ 4107 ] {} TCPHandler: Code: 44. DB::Exception: Second argument for function arrayLpDistance must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayDistance::initConstParams(std::vector> const&) const @ 0x000000002100c724 6. COW::immutable_ptr DB::FunctionArrayDistance::executeWithLeftArgConst(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002185a1c2 7. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftTypeAndRightType(COW::immutable_ptr, COW::immutable_ptr, unsigned long, std::vector> const&) const @ 0x000000002184dfcb 8. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultTypeAndLeftType(std::vector> const&, unsigned long) const @ 0x0000000021840620 9. COW::immutable_ptr DB::FunctionArrayDistance::executeWithResultType(std::vector> const&, unsigned long) const @ 0x0000000021723d8b 10. DB::FunctionArrayDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000217228c1 11. DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020d9943c 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 20. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 22. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 23. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 24. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:38:57.441749 [ 8099 ] {69471203-d988-4f9b-8b5e-57cf06a04d83} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:ea0a924c-5d72-41e2-91da-4aa17dc65692'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36172) (comment: 01782_field_oom.sql) (in query: CREATE DATABASE IF NOT EXISTS test_zhj2jp6h ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:57.449155 [ 8099 ] {69471203-d988-4f9b-8b5e-57cf06a04d83} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:ea0a924c-5d72-41e2-91da-4aa17dc65692'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:57.604178 [ 5978 ] {f58861cf-f58e-45d1-9ccc-9368a126b30f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:c613a937-47fa-4da5-abf3-390b3c77fb5a'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36198) (comment: 03234_evaluate_constant_analyzer.sql) (in query: CREATE DATABASE IF NOT EXISTS test_3shcr6ye ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:57.607863 [ 5978 ] {f58861cf-f58e-45d1-9ccc-9368a126b30f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:c613a937-47fa-4da5-abf3-390b3c77fb5a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:57.759785 [ 8099 ] {5d09776f-4acc-4a1d-9210-3d702649a873} 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.20286.altinityantalya (altinity build)) (from [::1]:48168) (comment: 02530_dictionaries_update_field.sh) (query 1, line 1) (in query: SELECT key, value FROM dict_complex_key_hashed ORDER BY key ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:57.786299 [ 5112 ] {a43082c0-4418-43e5-b961-9b51e5dfca1f} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `j1` in scope SELECT * EXCEPT STRICT i, j1 FROM columns_transformers. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47958) (comment: 01470_columns_transformers.sql) (query 14, line 19) (in query: SELECT * EXCEPT STRICT i, j1 from columns_transformers;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:38:57.792927 [ 8099 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:38:57.798631 [ 5112 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `j1` in scope SELECT * EXCEPT STRICT i, j1 FROM columns_transformers. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:38:57.841075 [ 7279 ] {a034f462-777b-46c3-9ffe-5c874d2f2f3d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:d70baa32-57cb-43c0-9b8c-f71d8638cf94'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36208) (comment: 00036_array_element.sql) (in query: CREATE DATABASE IF NOT EXISTS test_h50dsuj1 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:57.845706 [ 7279 ] {a034f462-777b-46c3-9ffe-5c874d2f2f3d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:d70baa32-57cb-43c0-9b8c-f71d8638cf94'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:57.924215 [ 3931 ] {743b6796-6c27-4dd0-b12a-b91514c9c871} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 2, should be 1: In scope SELECT formatQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 573, line 573) (in query: SELECT formatQuery(NULL, NULL);) 2025.06.13 15:38:57.941328 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 2, should be 1: In scope SELECT formatQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:57.966470 [ 9636 ] {2bb73362-3bfb-41c9-9121-937010f0050d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:928b4fc9-d08a-41f2-8808-11f85158dc38'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36220) (comment: 02365_multisearch_random_tests.sql) (in query: CREATE DATABASE IF NOT EXISTS test_9v0g1pqv ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:57.978768 [ 9636 ] {2bb73362-3bfb-41c9-9121-937010f0050d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:928b4fc9-d08a-41f2-8808-11f85158dc38'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:58.048231 [ 3931 ] {bc5b3f7b-555a-4daa-8b97-5d2a53737990} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 574, line 574) (in query: SELECT formatQueryOrNull(NULL, NULL);) 2025.06.13 15:38:58.059860 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:58.067477 [ 5112 ] {7b35c485-5919-44f3-9642-ed0f133cc0f6} executeQuery: Code: 36. DB::Exception: Strict EXCEPT column transformer EXCEPT (i, j1) expects following column(s) : j1. In scope SELECT * EXCEPT STRICT (i, j1) FROM columns_transformers. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47958) (comment: 01470_columns_transformers.sql) (query 15, line 20) (in query: SELECT * EXCEPT STRICT(i, j1) from columns_transformers;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type, std::type_identity::type>, char const*&&, String&&, fmt::v11::join_view, std::__wrap_iter, char>&&, String&&) @ 0x000000002cc5a20f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2437: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc40f5e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04d66 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:38:58.082628 [ 5112 ] {} TCPHandler: Code: 36. DB::Exception: Strict EXCEPT column transformer EXCEPT (i, j1) expects following column(s) : j1. In scope SELECT * EXCEPT STRICT (i, j1) FROM columns_transformers. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type, std::type_identity::type>, char const*&&, String&&, fmt::v11::join_view, std::__wrap_iter, char>&&, String&&) @ 0x000000002cc5a20f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2437: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc40f5e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04d66 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:38:58.110236 [ 8099 ] {5b383c26-b1d1-4d6a-b4d2-79095e214f14} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:1434dbc3-a92c-4b27-8e4e-83a3df28a211'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36234) (comment: 01325_freeze_mutation_stuck.sql) (in query: CREATE DATABASE IF NOT EXISTS test_7s3h9pb7 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:58.118751 [ 8099 ] {5b383c26-b1d1-4d6a-b4d2-79095e214f14} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:1434dbc3-a92c-4b27-8e4e-83a3df28a211'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:58.147679 [ 3931 ] {b277b9df-f0ab-4584-ad59-a5f5cadeb419} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 575, line 575) (in query: SELECT formatQuerySingleLine(NULL, NULL);) 2025.06.13 15:38:58.158550 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:58.254761 [ 3931 ] {c6a2f202-4ee7-4f86-aef1-755b54bd6cc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 576, line 576) (in query: SELECT formatQuerySingleLineOrNull(NULL, NULL);) 2025.06.13 15:38:58.263759 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:58.289255 [ 9636 ] {e6172904-e162-4c5f-96be-57862856aac4} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:6013b2ad-7f53-4525-8da7-c0e53bc04b15'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36248) (comment: 02125_lz4_compression_bug_Values.sh) (in query: CREATE DATABASE IF NOT EXISTS test_du6d4cxg ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:58.308077 [ 9636 ] {e6172904-e162-4c5f-96be-57862856aac4} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:6013b2ad-7f53-4525-8da7-c0e53bc04b15'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:58.348672 [ 5112 ] {4b77f0e2-534b-463d-9270-f7d7390bcd65} executeQuery: Code: 36. DB::Exception: Strict REPLACE column transformer REPLACE (i + 1 AS col) expects following column(s) : col. In scope SELECT * REPLACE STRICT (i + 1 AS col) FROM columns_transformers. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47958) (comment: 01470_columns_transformers.sql) (query 17, line 22) (in query: SELECT * REPLACE STRICT(i + 1 AS col) from columns_transformers;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type, std::type_identity::type>, char const*&&, String&&, fmt::v11::join_view, std::__wrap_iter, char>&&, String&&) @ 0x000000002cc5a20f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2437: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc40f5e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04d66 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:38:58.364144 [ 5112 ] {} TCPHandler: Code: 36. DB::Exception: Strict REPLACE column transformer REPLACE (i + 1 AS col) expects following column(s) : col. In scope SELECT * REPLACE STRICT (i + 1 AS col) FROM columns_transformers. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type, std::type_identity::type>, char const*&&, String&&, fmt::v11::join_view, std::__wrap_iter, char>&&, String&&) @ 0x000000002cc5a20f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2437: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc40f5e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04d66 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:38:58.397611 [ 3931 ] {217a7bb3-b220-4a09-a067-2f48d9ed8625} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 577, line 577) (in query: SELECT formatReadableDecimalSize(NULL, NULL);) 2025.06.13 15:38:58.406719 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:58.508078 [ 3931 ] {c07b6668-b1ee-4f30-98ac-629c7cb91561} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 2, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 578, line 578) (in query: SELECT formatReadableQuantity(NULL, NULL);) 2025.06.13 15:38:58.518204 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 2, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:58.542198 [ 6193 ] {52d02a6e-7214-4c4d-9bbc-6a3e5f5510fe} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:28e5c37e-6bd4-48a4-9753-015a9f7f570f'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36260) (comment: 02592_avro_more_types.sh) (in query: CREATE DATABASE IF NOT EXISTS test_sv8xv4p5 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:58.550575 [ 6193 ] {52d02a6e-7214-4c4d-9bbc-6a3e5f5510fe} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:28e5c37e-6bd4-48a4-9753-015a9f7f570f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:58.688376 [ 3931 ] {04617cc3-be6a-4582-9e31-b604cf940214} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 579, line 579) (in query: SELECT formatReadableSize(NULL, NULL);) 2025.06.13 15:38:58.695322 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:58.801627 [ 9636 ] {df7778b9-4525-4984-9e89-d385ca2fe613} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:e4587544-be69-4c4b-b4a1-6248c4280c26'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36264) (comment: 03254_trivial_merge_selector.sh) (in query: CREATE DATABASE IF NOT EXISTS test_c7a7u4qn ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:58.803484 [ 9636 ] {df7778b9-4525-4984-9e89-d385ca2fe613} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:e4587544-be69-4c4b-b4a1-6248c4280c26'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:58.907767 [ 3931 ] {5d7570ef-638a-415a-a195-45d4aae42dbc} executeQuery: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 581, line 581) (in query: SELECT formatRow(NULL, NULL);) 2025.06.13 15:38:58.924040 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:38:58.997857 [ 9636 ] {c861ec88-83fb-46d0-a420-d662e10aa86e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:c1dfbcbc-329d-460d-bb15-9c1f069edc53'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36278) (comment: 02891_rename_table_without_keyword.sql) (in query: CREATE DATABASE IF NOT EXISTS test_7ssrb2jq ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:59.011234 [ 9636 ] {c861ec88-83fb-46d0-a420-d662e10aa86e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:c1dfbcbc-329d-460d-bb15-9c1f069edc53'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:59.086674 [ 3931 ] {5269f3c2-1f71-4c4d-897f-427928816bd8} executeQuery: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 582, line 582) (in query: SELECT formatRowNoNewline(NULL, NULL);) 2025.06.13 15:38:59.102001 [ 5112 ] {3c947c6e-9c6e-4de2-a184-451011c72025} executeQuery: Code: 43. DB::Exception: Expressions in column transformer replace should not contain same replacement j more than once. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47958) (comment: 01470_columns_transformers.sql) (query 20, line 25) (in query: SELECT columns_transformers.* REPLACE(j + 1 AS j, j + 2 AS j) APPLY(avg) from columns_transformers;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Analyzer/ColumnTransformers.cpp:262: DB::ReplaceColumnTransformerNode::ReplaceColumnTransformerNode(std::vector> const&, bool) @ 0x000000002cbdb518 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>&, bool&, std::allocator, 0>(std::allocator, std::vector>&, bool&) @ 0x000000002cbc2f32 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::vector>&, bool&, 0>(std::allocator const&, std::vector>&, bool&) @ 0x000000002cbc2d80 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildColumnTransformers(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbb01d6 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:617: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9c312 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9b796 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba1716 12. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 15. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:38:59.109501 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:38:59.118181 [ 5112 ] {} TCPHandler: Code: 43. DB::Exception: Expressions in column transformer replace should not contain same replacement j more than once. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Analyzer/ColumnTransformers.cpp:262: DB::ReplaceColumnTransformerNode::ReplaceColumnTransformerNode(std::vector> const&, bool) @ 0x000000002cbdb518 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]>&, bool&, std::allocator, 0>(std::allocator, std::vector>&, bool&) @ 0x000000002cbc2f32 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::vector>&, bool&, 0>(std::allocator const&, std::vector>&, bool&) @ 0x000000002cbc2d80 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildColumnTransformers(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cbb01d6 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:617: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9c312 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9b796 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba1716 12. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 15. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:38:59.257873 [ 7755 ] {be5ef0cf-fdea-4205-9edb-356692743baa} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:5491a459-2e0c-431b-b990-52de3975d915'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36294) (comment: 02688_long_aggregate_function_names.sql) (in query: CREATE DATABASE IF NOT EXISTS test_l7djhgyx ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:59.264864 [ 7755 ] {be5ef0cf-fdea-4205-9edb-356692743baa} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:5491a459-2e0c-431b-b990-52de3975d915'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:59.285527 [ 3931 ] {278c383c-5cb6-4efe-8b1c-43cb9a023e08} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 2, should be 1: In scope SELECT fragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 583, line 583) (in query: SELECT fragment(NULL, NULL);) 2025.06.13 15:38:59.293976 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 2, should be 1: In scope SELECT fragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:59.445772 [ 3931 ] {b0ceaaf0-b27a-4bf5-8cb5-be134d92bb75} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 584, line 584) (in query: SELECT fromDaysSinceYearZero(NULL, NULL);) 2025.06.13 15:38:59.460084 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:59.470663 [ 8099 ] {0b73bc4c-950c-4d3a-b185-aefff5a53987} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:8ce8b6e8-5f8d-48fa-9df4-22fe4e7c8699'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36304) (comment: 01126_month_partitioning_consistent_code.sql) (in query: CREATE DATABASE IF NOT EXISTS test_2p120kvt ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:59.477126 [ 8099 ] {0b73bc4c-950c-4d3a-b185-aefff5a53987} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:8ce8b6e8-5f8d-48fa-9df4-22fe4e7c8699'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:59.568646 [ 3931 ] {11c40497-84c4-421f-9c75-b793013e4e3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 585, line 585) (in query: SELECT fromDaysSinceYearZero32(NULL, NULL);) 2025.06.13 15:38:59.585196 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:59.617800 [ 5112 ] {2967d7bf-ed74-4315-9bd9-7d65625f9792} executeQuery: Code: 36. DB::Exception: Strict REPLACE column transformer REPLACE (i + 1 AS i) expects following column(s) : i. In scope SELECT a.* APPLY toDate REPLACE STRICT (i + 1 AS i) APPLY any FROM columns_transformers AS a. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47958) (comment: 01470_columns_transformers.sql) (query 22, line 28) (in query: SELECT a.* APPLY(toDate) REPLACE STRICT(i + 1 AS i) APPLY(any) from columns_transformers a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type, std::type_identity::type>, char const*&&, String&&, fmt::v11::join_view, std::__wrap_iter, char>&&, String&&) @ 0x000000002cc5a20f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2437: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc40f5e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04d66 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:38:59.635132 [ 5112 ] {} TCPHandler: Code: 36. DB::Exception: Strict REPLACE column transformer REPLACE (i + 1 AS i) expects following column(s) : i. In scope SELECT a.* APPLY toDate REPLACE STRICT (i + 1 AS i) APPLY any FROM columns_transformers AS a. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type, std::type_identity::type>, char const*&&, String&&, fmt::v11::join_view, std::__wrap_iter, char>&&, String&&) @ 0x000000002cc5a20f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2437: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc40f5e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04d66 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:38:59.670326 [ 3931 ] {53db08f7-ed5d-4ad6-b3ed-a1f0e7c184f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 586, line 586) (in query: SELECT fromModifiedJulianDay(NULL, NULL);) 2025.06.13 15:38:59.680561 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:59.704956 [ 7755 ] {10a8d76a-511b-42b0-8dcc-453918720d09} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48254) (comment: 00976_system_stop_ttl_merges.sql) (query 2, line 3) (in query: CREATE TABLE ttl (`d` Date, `a` Int) ENGINE = MergeTree PARTITION BY toDayOfMonth(d) ORDER BY a TTL d + toIntervalDay(1) SETTINGS index_granularity = 59106, min_bytes_for_wide_part = 427677177, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 102, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 29488397, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 15327587, merge_max_block_size = 21912, old_parts_lifetime = 171., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 206852, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 27237440, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 90607, primary_key_compress_block_size = 73373, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:59.717108 [ 9636 ] {901958e8-8c36-449a-aa0b-3298d8c26ee6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:e094499c-7970-4263-b396-df768cb8fa25'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36318) (comment: 01268_dictionary_direct_layout.sql) (in query: CREATE DATABASE IF NOT EXISTS test_32vzquk9 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:59.719342 [ 9636 ] {901958e8-8c36-449a-aa0b-3298d8c26ee6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:e094499c-7970-4263-b396-df768cb8fa25'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:38:59.729231 [ 7755 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:38:59.802759 [ 3931 ] {3ac9ee90-af69-49fb-bee9-0d09ad43c02f} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 587, line 587) (in query: SELECT fromModifiedJulianDayOrNull(NULL, NULL);) 2025.06.13 15:38:59.821240 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:38:59.894285 [ 5978 ] {78d23993-7f37-4a64-9599-b10b93a72e87} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:7c5b83d2-259b-48a3-a724-e3ab58c6d22c'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36334) (comment: 01465_ttl_recompression.sql) (in query: CREATE DATABASE IF NOT EXISTS test_s0l3pf3s ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:38:59.906247 [ 5978 ] {78d23993-7f37-4a64-9599-b10b93a72e87} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:7c5b83d2-259b-48a3-a724-e3ab58c6d22c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:00.133865 [ 7279 ] {2b51307d-b5a4-47ca-af56-128b287bb1f9} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:249c041f-0517-4763-bc2e-4a13a414eda0'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36350) (comment: 01070_materialize_ttl.sql) (in query: CREATE DATABASE IF NOT EXISTS test_2l1t1wxt ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:00.141185 [ 7279 ] {2b51307d-b5a4-47ca-af56-128b287bb1f9} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:249c041f-0517-4763-bc2e-4a13a414eda0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:00.292957 [ 9636 ] {9e1f9275-b3e4-4cc7-a879-025d548d8dca} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:17cee439-bea4-464c-83e2-ea59724d4533'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36366) (comment: 02842_truncate_database.sql) (in query: CREATE DATABASE IF NOT EXISTS test_mgc38zrp ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:00.296339 [ 9636 ] {9e1f9275-b3e4-4cc7-a879-025d548d8dca} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:17cee439-bea4-464c-83e2-ea59724d4533'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:00.464853 [ 7279 ] {7245f757-0927-461e-86d2-189f5e2bf096} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:a37acfea-5770-42a6-baeb-9ef3847adaab'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36372) (comment: 01459_manual_write_to_replicas_quorum.sh) (in query: CREATE DATABASE IF NOT EXISTS test_nbpmie94 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:00.468728 [ 7279 ] {7245f757-0927-461e-86d2-189f5e2bf096} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:a37acfea-5770-42a6-baeb-9ef3847adaab'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:00.731130 [ 8101 ] {8e5792b4-876a-41c9-8e65-88dd1537d271} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:6ab34152-476b-4866-b225-71be18f5a6f2'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36384) (comment: 02102_sql_user_defined_functions_create_if_not_exists.sql) (in query: CREATE DATABASE IF NOT EXISTS test_l9vp7deb ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:00.738628 [ 8101 ] {8e5792b4-876a-41c9-8e65-88dd1537d271} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:6ab34152-476b-4866-b225-71be18f5a6f2'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:00.906289 [ 9643 ] {66d48c44-d59a-4407-8750-d8a907c5e435} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:ca926936-93f3-47f0-a54b-9b4023707255'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36398) (comment: 02096_rename_atomic_hang.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lk3q8mxz ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:00.908833 [ 9643 ] {66d48c44-d59a-4407-8750-d8a907c5e435} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:ca926936-93f3-47f0-a54b-9b4023707255'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:01.051219 [ 9636 ] {f5596967-7ae1-49e5-a0a0-0c833b0ca43e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:32691b2c-d2c8-4259-ad65-7c7adfa00ea4'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36400) (comment: 02104_json_strings_nullable_string.sh) (in query: CREATE DATABASE IF NOT EXISTS test_qkrvynfo ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:01.058837 [ 2862 ] {bf7fa3e8-3643-4f3e-81d2-fc39616255ef} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53500) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(`__table1`.`number`) AS `sum(number)` FROM `test_11`.`test_parallel_replicas_automatic_count` AS `__table1` LIMIT _CAST(1000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:39:01.075821 [ 2862 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:39:01.097795 [ 9636 ] {f5596967-7ae1-49e5-a0a0-0c833b0ca43e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:32691b2c-d2c8-4259-ad65-7c7adfa00ea4'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:01.215031 [ 6193 ] {02784_automatic_parallel_replicas-test_11_useless_limit_500k_pure} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48282) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count LIMIT 1_000_000 SETTINGS use_query_condition_cache = 0 format Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:39:01.235512 [ 6193 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:39:01.254946 [ 9636 ] {7d595796-e704-46f4-b605-cdf73b10d516} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:d7690138-2c11-49da-a36c-ca097df4680c'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36404) (comment: 02222_create_table_without_columns_metadata.sh) (in query: CREATE DATABASE IF NOT EXISTS test_j7jew2i8 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:01.258591 [ 9636 ] {7d595796-e704-46f4-b605-cdf73b10d516} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:d7690138-2c11-49da-a36c-ca097df4680c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:01.308770 [ 8442 ] {0d6f7d18-9bcc-4cb2-a4c1-1de5e002011e} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:43558). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:43558) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(`__table1`.`number`) AS `sum(number)` FROM `test_11`.`test_parallel_replicas_automatic_count` AS `__table1` LIMIT _CAST(1000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:1475: DB::TCPHandler::sendProfileEvents(DB::QueryState&) @ 0x00000000316cea2f 7. ./build_docker/./src/Server/TCPHandler.cpp:1490: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8fde 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:39:01.393303 [ 8442 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:43558). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:1475: DB::TCPHandler::sendProfileEvents(DB::QueryState&) @ 0x00000000316cea2f 7. ./build_docker/./src/Server/TCPHandler.cpp:1490: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8fde 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:39:01.578535 [ 9642 ] {2195cfef-25da-4e17-b4b0-25611f96e888} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:c11a6483-60e9-48ae-afd2-dfe7b280eac0'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36408) (comment: 03101_analyzer_identifiers_3.sql) (in query: CREATE DATABASE IF NOT EXISTS test_xonb2e8j ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:01.581518 [ 9642 ] {2195cfef-25da-4e17-b4b0-25611f96e888} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:c11a6483-60e9-48ae-afd2-dfe7b280eac0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:01.630750 [ 3931 ] {25fc557c-a727-4072-8119-b6853647953b} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT fullHostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 596, line 596) (in query: SELECT fullHostName(NULL, NULL);) 2025.06.13 15:39:01.640141 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT fullHostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:01.854944 [ 7279 ] {7b1f4d56-9be2-42a5-887c-111de0539075} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:7da0242c-4872-4d8d-9d4a-ed66775dca58'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36434) (comment: 02377_quota_key.sh) (in query: CREATE DATABASE IF NOT EXISTS test_g6fh2pfu ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:01.856932 [ 7279 ] {7b1f4d56-9be2-42a5-887c-111de0539075} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:7da0242c-4872-4d8d-9d4a-ed66775dca58'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:01.969885 [ 9636 ] {f6b07e1a-1c79-448f-b6bf-14c2f260d1eb} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48370) (comment: 01811_storage_buffer_flush_parameters.sh) (query 1, line 2) (in query: drop table buffer_01811;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:39:01.977283 [ 9636 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:39:01.995153 [ 4930 ] {b39b4955-a7e0-43b0-be57-0ce91a3d6ab1} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:082eb5de-af49-43b9-9deb-2ab607b88028'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36444) (comment: 00985_merge_stack_overflow.sql) (in query: CREATE DATABASE IF NOT EXISTS test_epv1did5 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:02.008641 [ 4930 ] {b39b4955-a7e0-43b0-be57-0ce91a3d6ab1} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:082eb5de-af49-43b9-9deb-2ab607b88028'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:02.101050 [ 9642 ] {286a3561-4af3-4dc1-94d5-7678703fe727} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:a82717f9-58c4-4078-a452-4f4581a50454'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36448) (comment: 03254_prewarm_mark_cache_columns.sql) (in query: CREATE DATABASE IF NOT EXISTS test_v1yow8s7 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:02.104349 [ 9642 ] {286a3561-4af3-4dc1-94d5-7678703fe727} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:a82717f9-58c4-4078-a452-4f4581a50454'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:02.241910 [ 5112 ] {ffbb1675-9ec6-48a0-8013-18053d31317f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=837). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47958) (comment: 01470_columns_transformers.sql) (query 37, line 47) (in query: -- Explicit column list SELECT COLUMNS(i, j, k) APPLY(sum) from columns_transformers;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:39:02.262495 [ 5112 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:39:02.315680 [ 9643 ] {7852b2c8-b46c-4325-bf84-df2111d342bf} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:9c453304-cba7-4cf0-9327-2b110026c584'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36464) (comment: 02895_npy_output_format.sh) (in query: CREATE DATABASE IF NOT EXISTS test_4so2yqb9 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:02.317798 [ 9643 ] {7852b2c8-b46c-4325-bf84-df2111d342bf} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:9c453304-cba7-4cf0-9327-2b110026c584'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:02.389091 [ 3931 ] {b0f8591b-c7b8-4e9d-a646-884da8035f36} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 2, should be 1: In scope SELECT generateSerialID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 601, line 601) (in query: SELECT generateSerialID(NULL, NULL);) 2025.06.13 15:39:02.397163 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 2, should be 1: In scope SELECT generateSerialID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:02.493049 [ 3931 ] {56a2bfb8-b52e-45fc-b338-d115f8451204} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: Nullable(Nothing): In scope SELECT generateSnowflakeID(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 602, line 602) (in query: SELECT generateSnowflakeID(NULL, NULL);) 2025.06.13 15:39:02.505387 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: Nullable(Nothing): In scope SELECT generateSnowflakeID(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:39:02.546673 [ 8431 ] {53e24ed8-8236-48af-bcd7-4d4b4055faa0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:57809dc7-ceb3-4c27-8f37-5a5c381a4b5e'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36472) (comment: 00052_group_by_in.sql) (in query: CREATE DATABASE IF NOT EXISTS test_pazamned ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:02.549548 [ 8431 ] {53e24ed8-8236-48af-bcd7-4d4b4055faa0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:57809dc7-ceb3-4c27-8f37-5a5c381a4b5e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:02.731932 [ 6234 ] {122291b9-0d3b-40d9-834e-cdccf1c09037} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:f35b373d-81f1-4aae-9c9d-8f75183985fe'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36484) (comment: 00054_merge_tree_partitions.sql) (in query: CREATE DATABASE IF NOT EXISTS test_wpjx74ex ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:02.737063 [ 6234 ] {122291b9-0d3b-40d9-834e-cdccf1c09037} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:f35b373d-81f1-4aae-9c9d-8f75183985fe'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:02.770643 [ 3931 ] {c90d2a73-d72f-488d-bdc3-c1f8ddbcfcb1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 604, line 604) (in query: SELECT generateUUIDv4(NULL, NULL);) 2025.06.13 15:39:02.778691 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:02.896912 [ 3931 ] {e4dfd2df-b575-4340-b9fc-71845bb78fa5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv7(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 605, line 605) (in query: SELECT generateUUIDv7(NULL, NULL);) 2025.06.13 15:39:02.908465 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv7(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:02.960949 [ 9636 ] {1e8ae29d-5147-4a7f-b253-8422e2c62c9f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:b50be0bd-e326-4450-aa0f-b033f7752889'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36498) (comment: 02494_query_cache_normalize_ast.sql) (in query: CREATE DATABASE IF NOT EXISTS test_fxcv9mzu ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:02.964489 [ 9636 ] {1e8ae29d-5147-4a7f-b253-8422e2c62c9f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:b50be0bd-e326-4450-aa0f-b033f7752889'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:03.065734 [ 3931 ] {9d98bf0e-17da-4c0a-b158-968f54938fd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 2, should be 4: In scope SELECT geoDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 606, line 606) (in query: SELECT geoDistance(NULL, NULL);) 2025.06.13 15:39:03.071716 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 2, should be 4: In scope SELECT geoDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:03.186948 [ 6234 ] {5f8d5011-f5b3-4417-9741-b0c01c46f86a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:a9c92724-2ce8-40b6-a700-daf129a9052a'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36502) (comment: 02402_external_disk_mertrics.sql) (in query: CREATE DATABASE IF NOT EXISTS test_2q8ine2x ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:03.191202 [ 6234 ] {5f8d5011-f5b3-4417-9741-b0c01c46f86a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:a9c92724-2ce8-40b6-a700-daf129a9052a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:03.191740 [ 3931 ] {ccc3ae39-c169-45dc-a268-9619b6103738} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 2, should be 3: In scope SELECT geoToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 607, line 607) (in query: SELECT geoToH3(NULL, NULL);) 2025.06.13 15:39:03.267908 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 2, should be 3: In scope SELECT geoToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:03.371010 [ 4930 ] {a02fcaa5-938e-4bfc-a6ec-19b46a4a8bd9} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:a59e1d48-5017-4673-886e-7a9b1d4abdb3'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44522) (comment: 02187_msg_pack_uuid.sh) (in query: CREATE DATABASE IF NOT EXISTS test_53je454m ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:03.375563 [ 4930 ] {a02fcaa5-938e-4bfc-a6ec-19b46a4a8bd9} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:a59e1d48-5017-4673-886e-7a9b1d4abdb3'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:03.506605 [ 3931 ] {d64587ec-7814-4078-8b7d-ff1a702b7609} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 2, should be 1: In scope SELECT geohashDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 609, line 609) (in query: SELECT geohashDecode(NULL, NULL);) 2025.06.13 15:39:03.514915 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 2, should be 1: In scope SELECT geohashDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:03.730405 [ 8432 ] {f013ff74-2a33-4656-b5a8-cf969ea4ba78} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:58288098-9ec8-4384-b584-4c94a2cda2a7'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44548) (comment: 01904_ssd_cache_dictionary_default_nullable_type.sh) (in query: CREATE DATABASE IF NOT EXISTS test_rsfoq6sa ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:03.733821 [ 8432 ] {f013ff74-2a33-4656-b5a8-cf969ea4ba78} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '6c2391fa62b7:9000:8000b16e-c6f3-42da-996e-5b065a75cd7b', current host ID: '6c2391fa62b7:9000:58288098-9ec8-4384-b584-4c94a2cda2a7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:03.751138 [ 6236 ] {80162ac2-cba5-41e6-bb80-c89f2712375f} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 9.00, current rows: 10.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48480) (comment: 01801_approx_total_rows_mergetree_reverse.sql) (query 3, line 4) (in query: select * from data_01801 where key = 0 order by key settings max_rows_to_read=9 format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3ace5b 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:39:03.770050 [ 6236 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 9.00, current rows: 10.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3ace5b 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:39:03.953038 [ 3931 ] {4a8eae5d-8bb1-4129-8ad0-330219fedfff} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 2, should be 5: In scope SELECT geohashesInBox(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 611, line 611) (in query: SELECT geohashesInBox(NULL, NULL);) 2025.06.13 15:39:03.966563 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 2, should be 5: In scope SELECT geohashesInBox(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:03.983785 [ 6236 ] {a2a02b3b-0dd5-4cc0-aa63-ab31dc1e0f14} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 9.00, current rows: 10.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InReverseOrder). (TOO_MANY_ROWS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48480) (comment: 01801_approx_total_rows_mergetree_reverse.sql) (query 4, line 5) (in query: select * from data_01801 where key = 0 order by key desc settings max_rows_to_read=9 format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3ace5b 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:39:03.998566 [ 6236 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 9.00, current rows: 10.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InReverseOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3ace5b 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:39:04.138139 [ 3931 ] {5da5efda-3c18-465c-8b00-63cfabb2dd70} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 612, line 612) (in query: SELECT getClientHTTPHeader(NULL, NULL);) 2025.06.13 15:39:04.143489 [ 3931 ] {} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.06.13 15:39:04.212508 [ 3931 ] {1c2405fe-d9f4-4eba-a775-05a72666c196} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 2, should be 1: In scope SELECT getMacro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 613, line 613) (in query: SELECT getMacro(NULL, NULL);) 2025.06.13 15:39:04.231425 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 2, should be 1: In scope SELECT getMacro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:04.327211 [ 3931 ] {42a5c802-bb17-47c1-8d94-0380205345c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 2, should be 1: In scope SELECT getMaxTableNameLengthForDatabase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 614, line 614) (in query: SELECT getMaxTableNameLengthForDatabase(NULL, NULL);) 2025.06.13 15:39:04.355893 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 2, should be 1: In scope SELECT getMaxTableNameLengthForDatabase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:04.482887 [ 3931 ] {166fdc27-8ddf-4886-8b91-220889572f79} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 2, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 615, line 615) (in query: SELECT getOSKernelVersion(NULL, NULL);) 2025.06.13 15:39:04.496353 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 2, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:04.669524 [ 3931 ] {9f025646-06a4-4cfe-ad01-113f24311261} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 2, should be 1: In scope SELECT getServerPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 616, line 616) (in query: SELECT getServerPort(NULL, NULL);) 2025.06.13 15:39:04.696316 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 2, should be 1: In scope SELECT getServerPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:04.843001 [ 3931 ] {5c5ab0d5-264f-41fd-9680-a6631e15a8bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 2, should be 1: In scope SELECT getSetting(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 617, line 617) (in query: SELECT getSetting(NULL, NULL);) 2025.06.13 15:39:04.851098 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 2, should be 1: In scope SELECT getSetting(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:05.132973 [ 3931 ] {83192c82-d7f2-4f98-bac7-318571a5fd2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 2, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 619, line 619) (in query: SELECT getSizeOfEnumType(NULL, NULL);) 2025.06.13 15:39:05.159439 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 2, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:05.248140 [ 3931 ] {1f19573c-7c87-41c4-a9ab-7b808a1110a5} 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(NULL, NULL). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 620, line 620) (in query: SELECT getSubcolumn(NULL, NULL);) 2025.06.13 15:39:05.255202 [ 3931 ] {} 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(NULL, NULL). (ILLEGAL_COLUMN) 2025.06.13 15:39:05.309542 [ 3931 ] {77a4cd6c-c407-474f-b3a3-afcee376a977} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 2, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 621, line 621) (in query: SELECT getTypeSerializationStreams(NULL, NULL);) 2025.06.13 15:39:05.323357 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 2, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:07.056131 [ 3931 ] {8d326e81-bf4f-4134-9174-4c9d63eaec19} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 2, should be 1: In scope SELECT globalVariable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 630, line 630) (in query: SELECT globalVariable(NULL, NULL);) 2025.06.13 15:39:07.066379 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 2, should be 1: In scope SELECT globalVariable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:07.178254 [ 3931 ] {6cca022a-fab3-43db-a984-5eb8a916687a} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 2, should be 4: In scope SELECT greatCircleAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 631, line 631) (in query: SELECT greatCircleAngle(NULL, NULL);) 2025.06.13 15:39:07.204374 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 2, should be 4: In scope SELECT greatCircleAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:07.310842 [ 3931 ] {b7fa4dbf-4dd2-4f3e-9ed9-18511964ff55} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 2, should be 4: In scope SELECT greatCircleDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 632, line 632) (in query: SELECT greatCircleDistance(NULL, NULL);) 2025.06.13 15:39:07.318755 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 2, should be 4: In scope SELECT greatCircleDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:08.697887 [ 4171 ] {3613b555-2831-4f4d-8ceb-593a29f0d320} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=833). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55878) (comment: 02971_functions_to_subcolumns_column_names.sql) (query 6, line 10) (in query: EXPLAIN QUERY TREE dump_tree = 0, dump_ast = 1 SELECT length(arr), isNull(n) FROM t_column_names;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:39:08.707658 [ 4171 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=833). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:39:10.636727 [ 2862 ] {b19a4051-0699-440b-9d97-52a011679c8b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55988) (comment: 00371_union_all.sql) (query 1, line 1) (in query: select toUInt64(1) union all select countIf(n>0) from (select 2 as n);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:39:10.665723 [ 2862 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:39:11.587942 [ 3931 ] {42890fec-e399-48c2-8114-0203f2740ec4} executeQuery: Code: 43. DB::Exception: If groupConcat is used with two arguments, the second argument must be a constant String. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 651, line 651) (in query: SELECT groupConcat(NULL, NULL);) 2025.06.13 15:39:11.603281 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: If groupConcat is used with two arguments, the second argument must be a constant String. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:39:11.762092 [ 3543 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {20042b95-f80d-4029-990a-e2a00a75ad0e::lambda}: Code: 107. DB::Exception: File or directory store/200/20042b95-f80d-4029-990a-e2a00a75ad0e/tmp_merge_6_8_8_1/a.cmrk2 does not exist on PlainRewritableS3ObjectStorage. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Disks/ObjectStorages/MetadataStorageFromPlainObjectStorage.cpp:101: DB::MetadataStorageFromPlainObjectStorage::getLastModified(String const&) const @ 0x000000002ca47916 6. ./build_docker/./src/Disks/ObjectStorages/DiskObjectStorage.cpp:420: DB::DiskObjectStorage::getLastModified(String const&) const @ 0x000000002c9ab6b5 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2519: DB::MergeTreeData::clearOldTemporaryDirectories(String const&, unsigned long, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x0000000030ca5561 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2530: DB::MergeTreeData::clearOldTemporaryDirectories(unsigned long, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x0000000030ca4862 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:1505: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003120fac5 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b3595c 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c632bd 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c63eff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:12.002457 [ 3931 ] {810a2a2c-f9b2-46a8-85c0-329859e2d410} executeQuery: Code: 43. DB::Exception: If groupConcat is used with two arguments, the second argument must be a constant String. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 653, line 653) (in query: SELECT group_concat(NULL, NULL);) 2025.06.13 15:39:12.012263 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: If groupConcat is used with two arguments, the second argument must be a constant String. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:39:12.093369 [ 6193 ] {5db8a8f4-40ba-4c9c-bcb0-c09d1a29031a} 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.20286.altinityantalya (altinity build)) (from [::1]:56068) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1510: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7347d 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:39:12.113612 [ 6193 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1510: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc7347d 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:39:12.187756 [ 3931 ] {f5396499-5602-4098-b9fe-24c91506d5f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 654, line 654) (in query: SELECT h3CellAreaM2(NULL, NULL);) 2025.06.13 15:39:12.210137 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:12.376372 [ 3931 ] {8a8d7180-8bea-40d5-acbf-27e148f651e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 655, line 655) (in query: SELECT h3CellAreaRads2(NULL, NULL);) 2025.06.13 15:39:12.404813 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:12.726310 [ 3931 ] {3bcfa29b-d585-469f-bd5e-d3b259539f62} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 2, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 657, line 657) (in query: SELECT h3EdgeAngle(NULL, NULL);) 2025.06.13 15:39:12.747169 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 2, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:12.863527 [ 3931 ] {97c6454b-d882-4a1f-bdbe-e7ea38677715} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 658, line 658) (in query: SELECT h3EdgeLengthKm(NULL, NULL);) 2025.06.13 15:39:12.874683 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:12.967103 [ 3931 ] {e901d5f6-bb5b-4aeb-b0c6-c6b72814f3f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 659, line 659) (in query: SELECT h3EdgeLengthM(NULL, NULL);) 2025.06.13 15:39:12.977438 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:13.145502 [ 3931 ] {9e5cd9c6-fe71-40a1-bada-d86e3fe0986d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 660, line 660) (in query: SELECT h3ExactEdgeLengthKm(NULL, NULL);) 2025.06.13 15:39:13.161840 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:13.289114 [ 3931 ] {c98798d3-617d-4c15-8a1b-5adb273f3843} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 661, line 661) (in query: SELECT h3ExactEdgeLengthM(NULL, NULL);) 2025.06.13 15:39:13.307928 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:13.455152 [ 6193 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:13.457959 [ 6193 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:39:13.463458 [ 3931 ] {1504b5df-f06e-45c0-a639-b037fde011a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 662, line 662) (in query: SELECT h3ExactEdgeLengthRads(NULL, NULL);) 2025.06.13 15:39:13.483184 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:13.563511 [ 3931 ] {1d6bb53a-55f5-418c-8ef7-6817e2ec7039} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 2, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 663, line 663) (in query: SELECT h3GetBaseCell(NULL, NULL);) 2025.06.13 15:39:13.571602 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 2, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:13.737699 [ 3931 ] {6d4ffdd6-6b3d-4f84-ae5c-5efd5c6716f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 664, line 664) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL);) 2025.06.13 15:39:13.754486 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:13.835875 [ 4930 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:13.837069 [ 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:39:13.856813 [ 3931 ] {782a1efc-1f85-4bb5-abcf-2c283dac155e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 2, should be 1: In scope SELECT h3GetFaces(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 665, line 665) (in query: SELECT h3GetFaces(NULL, NULL);) 2025.06.13 15:39:13.866841 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 2, should be 1: In scope SELECT h3GetFaces(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:13.987991 [ 3931 ] {ec554f80-b849-45eb-9f00-bf39bbebb791} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 666, line 666) (in query: SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL);) 2025.06.13 15:39:14.008331 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:14.093326 [ 3931 ] {406aeef1-0dfd-40e9-bdcb-7a099df37933} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 667, line 667) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL);) 2025.06.13 15:39:14.116667 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:14.337396 [ 3931 ] {ef026f2e-6756-4652-9886-efe6b2ea45d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 2, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 668, line 668) (in query: SELECT h3GetPentagonIndexes(NULL, NULL);) 2025.06.13 15:39:14.343402 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 2, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:14.577568 [ 3931 ] {a8986131-e34b-44ca-b4bd-7438d3a5bf43} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 2, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 669, line 669) (in query: SELECT h3GetRes0Indexes(NULL, NULL);) 2025.06.13 15:39:14.584060 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 2, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:14.658219 [ 6193 ] {46b64069-778c-4934-9e91-42d96837de17} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT data FROM t_json_files ORDER BY file ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44286) (comment: 01825_type_json_multiple_files.sh) (query 1, line 1) (in query: SELECT data FROM t_json_files ORDER BY file FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:39:14.679136 [ 6193 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT data FROM t_json_files ORDER BY file ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:39:14.748782 [ 3931 ] {80ec4254-67de-4954-9e00-a5a8ef27237f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 2, should be 1: In scope SELECT h3GetResolution(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 670, line 670) (in query: SELECT h3GetResolution(NULL, NULL);) 2025.06.13 15:39:14.784168 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 2, should be 1: In scope SELECT h3GetResolution(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:15.057976 [ 3931 ] {6d3941d2-2f6c-4418-a362-52dcb4704375} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 672, line 672) (in query: SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL);) 2025.06.13 15:39:15.070913 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:15.113719 [ 6193 ] {eec4f1a5-b3a5-447e-8885-fd546b1811ac} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT toTypeName(data) FROM t_json_files LIMIT 1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44338) (comment: 01825_type_json_multiple_files.sh) (query 1, line 1) (in query: SELECT toTypeName(data) FROM t_json_files LIMIT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:39:15.114050 [ 3931 ] {1cead4e6-1711-492e-bfb9-7929b2da3315} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 673, line 673) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL);) 2025.06.13 15:39:15.127256 [ 6193 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT toTypeName(data) FROM t_json_files LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:39:15.134974 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:15.193130 [ 3931 ] {9624d355-d769-41cd-a8d1-96091e4fd0a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 674, line 674) (in query: SELECT h3HexAreaKm2(NULL, NULL);) 2025.06.13 15:39:15.203759 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:15.282393 [ 3931 ] {bcadc4bf-d6c1-4b0f-8d02-c6626f1b7e1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 675, line 675) (in query: SELECT h3HexAreaM2(NULL, NULL);) 2025.06.13 15:39:15.292772 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:15.641341 [ 3931 ] {64a00242-b591-4d11-969c-91d724a378ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 2, should be 1: In scope SELECT h3IsPentagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 678, line 678) (in query: SELECT h3IsPentagon(NULL, NULL);) 2025.06.13 15:39:15.736883 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 2, should be 1: In scope SELECT h3IsPentagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:15.849921 [ 3931 ] {e882e47f-98fb-43a5-8789-10a0686aa8ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 2, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 679, line 679) (in query: SELECT h3IsResClassIII(NULL, NULL);) 2025.06.13 15:39:15.864420 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 2, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:15.948065 [ 3931 ] {18406e2e-96ea-4620-9946-f39536abcf88} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 2, should be 1: In scope SELECT h3IsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 680, line 680) (in query: SELECT h3IsValid(NULL, NULL);) 2025.06.13 15:39:15.994402 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 2, should be 1: In scope SELECT h3IsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:16.202937 [ 3894 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:16.205826 [ 3894 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:39:16.373697 [ 3931 ] {d49ffce3-b4c1-4c2c-ac1c-c2e6cd2f5b87} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 2, should be 1: In scope SELECT h3NumHexagons(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 682, line 682) (in query: SELECT h3NumHexagons(NULL, NULL);) 2025.06.13 15:39:16.384055 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 2, should be 1: In scope SELECT h3NumHexagons(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:16.471392 [ 3931 ] {702c599c-562e-4df0-9fdd-f0fddd06377c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 2, should be 4: In scope SELECT h3PointDistKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 683, line 683) (in query: SELECT h3PointDistKm(NULL, NULL);) 2025.06.13 15:39:16.482050 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 2, should be 4: In scope SELECT h3PointDistKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:16.658838 [ 3931 ] {81af570c-f146-46a2-aeab-725ef719ec9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 2, should be 4: In scope SELECT h3PointDistM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 684, line 684) (in query: SELECT h3PointDistM(NULL, NULL);) 2025.06.13 15:39:16.663669 [ 3894 ] {c0ea54c2-3e1d-4d8a-9368-b626e2da53fc} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT data FROM t_json_files ORDER BY file ASC, data ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44396) (comment: 01825_type_json_multiple_files.sh) (query 1, line 1) (in query: SELECT data FROM t_json_files ORDER BY file, data FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:39:16.685702 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 2, should be 4: In scope SELECT h3PointDistM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:16.688649 [ 3894 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT data FROM t_json_files ORDER BY file ASC, data ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:39:16.794119 [ 3931 ] {303bec5e-03b2-47e8-9666-0dc77e0a3442} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 2, should be 4: In scope SELECT h3PointDistRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 685, line 685) (in query: SELECT h3PointDistRads(NULL, NULL);) 2025.06.13 15:39:16.804294 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 2, should be 4: In scope SELECT h3PointDistRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:17.165383 [ 3894 ] {b062d641-7254-4da2-9450-5182448fc1ec} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT toTypeName(data) FROM t_json_files LIMIT 1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44416) (comment: 01825_type_json_multiple_files.sh) (query 1, line 1) (in query: SELECT toTypeName(data) FROM t_json_files LIMIT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:39:17.204261 [ 3894 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT toTypeName(data) FROM t_json_files LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:39:17.247421 [ 3931 ] {e323b838-c55b-4910-b7fe-dae93a081536} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 2, should be 1: In scope SELECT h3ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 688, line 688) (in query: SELECT h3ToGeo(NULL, NULL);) 2025.06.13 15:39:17.258378 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 2, should be 1: In scope SELECT h3ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:17.459849 [ 6236 ] {a803e374-e015-4d9a-9854-d4dccefc855d} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44434) (comment: 02530_dictionaries_update_field.sh) (query 1, line 1) (in query: DROP DICTIONARY dict_complex_key_hashed_custom), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:39:17.465307 [ 3931 ] {f64c7562-3a1c-4d3f-860d-980c07028df3} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 2, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 689, line 689) (in query: SELECT h3ToGeoBoundary(NULL, NULL);) 2025.06.13 15:39:17.488717 [ 6236 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:39:17.508524 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 2, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:17.794527 [ 3931 ] {6ec554f7-36f9-4c47-a9cf-dd34f153bdb3} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 2, should be 1: In scope SELECT h3ToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 691, line 691) (in query: SELECT h3ToString(NULL, NULL);) 2025.06.13 15:39:17.887459 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 2, should be 1: In scope SELECT h3ToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:17.951829 [ 3931 ] {6c5b4038-0089-4fc8-8124-22240b2e9489} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 2, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 692, line 692) (in query: SELECT h3UnidirectionalEdgeIsValid(NULL, NULL);) 2025.06.13 15:39:17.966049 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 2, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:18.126829 [ 6234 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:18.129028 [ 6234 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:39:18.183560 [ 6193 ] {643b4c62-4f8a-4116-a04c-7cfceabc224a} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_lgs2svyc.table_for_update_field_dictionary (6dda5caf-9dd7-423a-b600-93a10ec351c2), because some tables depend on it: test_lgs2svyc.dict_hashed_custom, test_lgs2svyc.dict_complex_key_hashed_custom, test_lgs2svyc.dict_flat. (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44466) (comment: 02530_dictionaries_update_field.sh) (query 1, line 1) (in query: DROP TABLE IF EXISTS table_for_update_field_dictionary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d60a06f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd0c4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd596 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca75b3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:18.198642 [ 6193 ] {} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_lgs2svyc.table_for_update_field_dictionary (6dda5caf-9dd7-423a-b600-93a10ec351c2), because some tables depend on it: test_lgs2svyc.dict_hashed_custom, test_lgs2svyc.dict_complex_key_hashed_custom, test_lgs2svyc.dict_flat. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d60a06f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd0c4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd596 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca75b3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:18.425201 [ 3931 ] {1f8f90bf-db8a-4929-a295-14e5774bb2d3} executeQuery: Code: 43. DB::Exception: First argument for function has must be an array or map. Actual Nullable(Nothing): In scope SELECT has(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 695, line 695) (in query: SELECT has(NULL, NULL);) 2025.06.13 15:39:18.443319 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function has must be an array or map. Actual Nullable(Nothing): In scope SELECT has(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:39:18.576424 [ 6193 ] {9ba54de3-3ae4-44a9-822d-8c46f85a70f4} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45266) (comment: 02530_dictionaries_update_field.sh) (in query: DROP DATABASE IF EXISTS test_lgs2svyc SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:18.592240 [ 6234 ] {b41d0767-722a-40c8-9553-d4969ae9a454} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT data FROM t_json_files ORDER BY file ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44508) (comment: 01825_type_json_multiple_files.sh) (query 1, line 1) (in query: SELECT data FROM t_json_files ORDER BY file FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:39:18.598946 [ 6193 ] {9ba54de3-3ae4-44a9-822d-8c46f85a70f4} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:18.613475 [ 6234 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT data FROM t_json_files ORDER BY file ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:39:19.151847 [ 3894 ] {dc2b9ffa-b41d-4d80-bf1e-e67e78262e8f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT toTypeName(data) FROM t_json_files LIMIT 1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44538) (comment: 01825_type_json_multiple_files.sh) (query 1, line 1) (in query: SELECT toTypeName(data) FROM t_json_files LIMIT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:39:19.176323 [ 3894 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT toTypeName(data) FROM t_json_files LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:39:19.454802 [ 8099 ] {0774dc2e-0489-465b-b512-84dabff6fd11} executeQuery: Code: 43. DB::Exception: Nested type Array(String) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44484) (comment: 01159_combinators_with_parameters.sql) (query 6, line 6) (in query: SELECT toTypeName(topKOrNullState(10)(toString(number))) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x000000002c43cd5d 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::allocator, 0>(std::allocator, std::shared_ptr const&) @ 0x000000002846a5d9 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x000000002846a3e0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::AggregateFunctionOrFill::createResultType(std::shared_ptr const&) @ 0x0000000028464948 9. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:37: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846440d 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107] const&, std::vector, std::allocator>> const&, DB::Array const&, std::allocator>, 0>(std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846408b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028463e6c 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028463d71 13. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4987 14. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 15. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4117 16. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:39:19.476825 [ 8099 ] {} TCPHandler: Code: 43. DB::Exception: Nested type Array(String) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x000000002c43cd5d 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::allocator, 0>(std::allocator, std::shared_ptr const&) @ 0x000000002846a5d9 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x000000002846a3e0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::AggregateFunctionOrFill::createResultType(std::shared_ptr const&) @ 0x0000000028464948 9. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:37: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846440d 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107] const&, std::vector, std::allocator>> const&, DB::Array const&, std::allocator>, 0>(std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846408b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028463e6c 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028463d71 13. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4987 14. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 15. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4117 16. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:39:20.068655 [ 3931 ] {d936dd93-6572-46a1-8c1b-26da7c0c6c71} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 2, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 704, line 704) (in query: SELECT hasThreadFuzzer(NULL, NULL);) 2025.06.13 15:39:20.080230 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 2, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:21.125543 [ 3931 ] {67199841-b4cb-443e-80fe-62cfc4bebf87} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 2, should be 1: In scope SELECT hex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 709, line 709) (in query: SELECT hex(NULL, NULL);) 2025.06.13 15:39:21.139423 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 2, should be 1: In scope SELECT hex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:22.429039 [ 4107 ] {20042b95-f80d-4029-990a-e2a00a75ad0e::0_1_2_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b868270 10. ./build_docker/./src/IO/WriteBufferFromS3.cpp:782: DB::WriteBufferFromS3::makeSinglepartUpload(DB::WriteBufferFromS3::PartData&&) @ 0x000000002b844eb4 11. ./build_docker/./src/IO/WriteBufferFromS3.cpp:194: DB::WriteBufferFromS3::preFinalize() @ 0x000000002b8443d7 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:73: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000002ca0860f 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:47: DB::MergeTreeDataPartWriterOnDisk::Stream::preFinalize() @ 0x0000000030df298f 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:712: DB::MergeTreeDataPartWriterWide::fillDataChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000030e01afc 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:749: DB::MergeTreeDataPartWriterWide::fillChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000030e02922 16. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:213: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000030ff1c1f 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:195: DB::MergedBlockOutputStream::finalizePart(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000030ff19cb 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::MergeProjectionsStage::finalizeProjectionsAndWholeMerge() const @ 0x0000000030c26ec1 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1425: DB::MergeTask::MergeProjectionsStage::execute() @ 0x0000000030c282f7 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 22. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 23. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 24. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:22.592231 [ 3931 ] {2c481973-8d96-4c5f-ab60-57ede34bce90} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 717, line 717) (in query: SELECT hostName(NULL, NULL);) 2025.06.13 15:39:22.607424 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:22.657822 [ 4107 ] {f8b261f1-3b78-4720-adc9-cc35fb14ead3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=4). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55914) (comment: 03008_s3_plain_rewritable.sh) (query 1, line 1) (in query: optimize table test_s3_mt final), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b868270 10. ./build_docker/./src/IO/WriteBufferFromS3.cpp:782: DB::WriteBufferFromS3::makeSinglepartUpload(DB::WriteBufferFromS3::PartData&&) @ 0x000000002b844eb4 11. ./build_docker/./src/IO/WriteBufferFromS3.cpp:194: DB::WriteBufferFromS3::preFinalize() @ 0x000000002b8443d7 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:73: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000002ca0860f 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:47: DB::MergeTreeDataPartWriterOnDisk::Stream::preFinalize() @ 0x0000000030df298f 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:712: DB::MergeTreeDataPartWriterWide::fillDataChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000030e01afc 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:749: DB::MergeTreeDataPartWriterWide::fillChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000030e02922 16. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:213: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000030ff1c1f 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:195: DB::MergedBlockOutputStream::finalizePart(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000030ff19cb 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::MergeProjectionsStage::finalizeProjectionsAndWholeMerge() const @ 0x0000000030c26ec1 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1425: DB::MergeTask::MergeProjectionsStage::execute() @ 0x0000000030c282f7 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 22. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 23. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 24. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:39:22.668292 [ 4107 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b868270 10. ./build_docker/./src/IO/WriteBufferFromS3.cpp:782: DB::WriteBufferFromS3::makeSinglepartUpload(DB::WriteBufferFromS3::PartData&&) @ 0x000000002b844eb4 11. ./build_docker/./src/IO/WriteBufferFromS3.cpp:194: DB::WriteBufferFromS3::preFinalize() @ 0x000000002b8443d7 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:73: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x000000002ca0860f 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:47: DB::MergeTreeDataPartWriterOnDisk::Stream::preFinalize() @ 0x0000000030df298f 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:712: DB::MergeTreeDataPartWriterWide::fillDataChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000030e01afc 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:749: DB::MergeTreeDataPartWriterWide::fillChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x0000000030e02922 16. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:213: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000030ff1c1f 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:195: DB::MergedBlockOutputStream::finalizePart(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000030ff19cb 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::MergeProjectionsStage::finalizeProjectionsAndWholeMerge() const @ 0x0000000030c26ec1 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1425: DB::MergeTask::MergeProjectionsStage::execute() @ 0x0000000030c282f7 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 22. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 23. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 24. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:39:22.732393 [ 3931 ] {b8e316c6-9ed9-41e2-ba0b-15ca02fe8d60} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostname(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 718, line 718) (in query: SELECT hostname(NULL, NULL);) 2025.06.13 15:39:22.747782 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostname(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:23.207265 [ 3931 ] {1618bfbc-e6ae-4141-89a3-e922ed99731f} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergHash doesn't match: passed 2, should be 1: In scope SELECT icebergHash(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 721, line 721) (in query: SELECT icebergHash(NULL, NULL);) 2025.06.13 15:39:23.214248 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergHash doesn't match: passed 2, should be 1: In scope SELECT icebergHash(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:23.369769 [ 8101 ] {3aee4599-0b60-476b-bce8-09aa594660ff} executeQuery: Code: 344. DB::Exception: ALTER TABLE commands are not supported on immutable disk '03008_s3_plain_rewritable', except for setting and comment alteration. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55472) (comment: 03008_s3_plain_rewritable.sh) (query 1, line 2) (in query: alter table test_s3_mt add projection test_s3_mt_projection (select * order by b)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3559: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccb0d4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:39:23.394481 [ 8101 ] {} TCPHandler: Code: 344. DB::Exception: ALTER TABLE commands are not supported on immutable disk '03008_s3_plain_rewritable', except for setting and comment alteration. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3559: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccb0d4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:39:23.481827 [ 3931 ] {4bee25d1-4ea8-44f6-9263-3555df289716} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 2, should be 1: In scope SELECT identity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 723, line 723) (in query: SELECT identity(NULL, NULL);) 2025.06.13 15:39:23.496288 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 2, should be 1: In scope SELECT identity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:23.620138 [ 3931 ] {d66e7a8b-b8e0-48d5-8c39-51f26e288e79} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 2, should be 1: In scope SELECT idnaDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 724, line 724) (in query: SELECT idnaDecode(NULL, NULL);) 2025.06.13 15:39:23.695870 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 2, should be 1: In scope SELECT idnaDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:23.774905 [ 3931 ] {2daa7394-0efa-4f18-b549-e5835894979e} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 2, should be 1: In scope SELECT idnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 725, line 725) (in query: SELECT idnaEncode(NULL, NULL);) 2025.06.13 15:39:23.786838 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 2, should be 1: In scope SELECT idnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:23.848319 [ 4171 ] {af70e519-6c17-4a67-9448-9e71270f6ce9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44662) (comment: 00577_replacing_merge_tree_vertical_merge.sql) (query 6, line 9) (in query: select * from tab_00577 order by version;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f585dc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f5af07 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f54898 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f54302 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dd53bf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dcd2b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:205: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000322151a0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 2025.06.13 15:39:23.895243 [ 5110 ] {dd6dd45b-9ec8-4237-8c00-0eb09401240e} executeQuery: Code: 344. DB::Exception: Mutations are not supported for immutable disk '03008_s3_plain_rewritable'. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55488) (comment: 03008_s3_plain_rewritable.sh) (query 1, line 2) (in query: alter table test_s3_mt update c = 0 where a % 2 = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3970: DB::MergeTreeData::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x0000000030cd3b1a 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc415b6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:39:23.901288 [ 4171 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f585dc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f5af07 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f54898 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f54302 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dd53bf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dcd2b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:205: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000322151a0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:39:23.913385 [ 5110 ] {} TCPHandler: Code: 344. DB::Exception: Mutations are not supported for immutable disk '03008_s3_plain_rewritable'. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3970: DB::MergeTreeData::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x0000000030cd3b1a 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc415b6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:39:23.997334 [ 3931 ] {bfc9f0c6-efca-4b16-be39-d41314cea724} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 2, should be 3: In scope SELECT if(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 726, line 726) (in query: SELECT if(NULL, NULL);) 2025.06.13 15:39:24.004637 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 2, should be 3: In scope SELECT if(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:25.403029 [ 3931 ] {01b8c448-8fd6-4e99-9887-ab1114c1a4e6} executeQuery: Code: 43. DB::Exception: First argument for function indexOf must be an array. Actual Nullable(Nothing): In scope SELECT indexOf(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 734, line 734) (in query: SELECT indexOf(NULL, NULL);) 2025.06.13 15:39:25.441399 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function indexOf must be an array. Actual Nullable(Nothing): In scope SELECT indexOf(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:39:25.609532 [ 3931 ] {4ee9c40c-ef17-45f5-9f28-4495ff12a07a} executeQuery: Code: 43. DB::Exception: First argument for function indexOfAssumeSorted must be an array. Actual Nullable(Nothing): In scope SELECT indexOfAssumeSorted(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 735, line 735) (in query: SELECT indexOfAssumeSorted(NULL, NULL);) 2025.06.13 15:39:25.618267 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function indexOfAssumeSorted must be an array. Actual Nullable(Nothing): In scope SELECT indexOfAssumeSorted(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:39:25.722078 [ 3931 ] {8f4aff66-61af-4342-b8e1-7611837a7385} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 2, should be 1: In scope SELECT initcap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 736, line 736) (in query: SELECT initcap(NULL, NULL);) 2025.06.13 15:39:25.730163 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 2, should be 1: In scope SELECT initcap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:25.847643 [ 3931 ] {95b9e2dc-6aed-4d7f-aa30-3997c641ead8} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 2, should be 1: In scope SELECT initcapUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 737, line 737) (in query: SELECT initcapUTF8(NULL, NULL);) 2025.06.13 15:39:25.856090 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 2, should be 1: In scope SELECT initcapUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:26.093174 [ 3931 ] {e6fd16f4-c90b-4a8d-a175-3905e3dc5ab6} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initialQueryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 738, line 738) (in query: SELECT initialQueryID(NULL, NULL);) 2025.06.13 15:39:26.107051 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initialQueryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:26.184937 [ 3931 ] {67d7a124-96dc-4690-869d-3dafe442bad6} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 2, should be 0: In scope SELECT initialQueryStartTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 739, line 739) (in query: SELECT initialQueryStartTime(NULL, NULL);) 2025.06.13 15:39:26.198628 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 2, should be 0: In scope SELECT initialQueryStartTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:26.356627 [ 3931 ] {b598dde1-2357-4fc4-831b-1d464c78c6b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initial_query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 740, line 740) (in query: SELECT initial_query_id(NULL, NULL);) 2025.06.13 15:39:26.369282 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initial_query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:26.463477 [ 3931 ] {d31f01af-4a0a-48d7-ba5c-91a273e0f51f} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 2, should be 0: In scope SELECT initial_query_start_time(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 741, line 741) (in query: SELECT initial_query_start_time(NULL, NULL);) 2025.06.13 15:39:26.471316 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 2, should be 0: In scope SELECT initial_query_start_time(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:26.547377 [ 3931 ] {a87d343f-20aa-442e-98ba-4a5458dfa71c} executeQuery: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 742, line 742) (in query: SELECT initializeAggregation(NULL, NULL);) 2025.06.13 15:39:26.565853 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:39:27.092293 [ 4171 ] {1d053604-8591-4fe1-85fc-0f7478763200} executeQuery: Code: 131. DB::Exception: Too long name of aggregate function, maximum: 1000. (TOO_LARGE_STRING_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55548) (comment: 02688_long_aggregate_function_names.sql) (query 1, line 1) (in query: SELECT minOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNullOrNull(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c81c0f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:332: DB::AggregateFunctionFactory::isAggregateFunctionName(String const&) const @ 0x000000002b3c5fd9 6. ./src/Analyzer/Resolve/ExpressionsStack.h:23: DB::ExpressionsStack::push(std::shared_ptr const&) @ 0x000000002cc92795 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3681: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc046df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:39:27.106399 [ 4171 ] {} TCPHandler: Code: 131. DB::Exception: Too long name of aggregate function, maximum: 1000. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c81c0f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:332: DB::AggregateFunctionFactory::isAggregateFunctionName(String const&) const @ 0x000000002b3c5fd9 6. ./src/Analyzer/Resolve/ExpressionsStack.h:23: DB::ExpressionsStack::push(std::shared_ptr const&) @ 0x000000002cc92795 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3681: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc046df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:39:27.481625 [ 3931 ] {cba1edcf-11c7-4159-a32c-31db30f8e8b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 2, should be 1: In scope SELECT intExp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 746, line 746) (in query: SELECT intExp10(NULL, NULL);) 2025.06.13 15:39:27.491180 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 2, should be 1: In scope SELECT intExp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:27.728946 [ 3931 ] {b755e7c3-e2fb-4d9a-9ec0-3bb277274cbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 2, should be 1: In scope SELECT intExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 747, line 747) (in query: SELECT intExp2(NULL, NULL);) 2025.06.13 15:39:27.738220 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 2, should be 1: In scope SELECT intExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:27.803343 [ 3931 ] {b0519bf3-5047-4cc5-922e-a0bb48126f6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 2, should be 1: In scope SELECT intHash32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 748, line 748) (in query: SELECT intHash32(NULL, NULL);) 2025.06.13 15:39:27.817843 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 2, should be 1: In scope SELECT intHash32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:27.998535 [ 8442 ] {b1e055c0-158c-44aa-94ae-57ce3b38a8fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 0, should be 2: In scope SELECT arrayShingles(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55570) (comment: 02891_array_shingles.sql) (query 2, line 2) (in query: SELECT arrayShingles();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:39:28.004244 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 0, should be 2: In scope SELECT arrayShingles(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:39:28.010110 [ 3931 ] {6e9a9021-5730-4cbc-8a37-c1be34139ce4} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 2, should be 1: In scope SELECT intHash64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 749, line 749) (in query: SELECT intHash64(NULL, NULL);) 2025.06.13 15:39:28.016037 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 2, should be 1: In scope SELECT intHash64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:28.118175 [ 8442 ] {5dd851bf-b536-400e-a21f-5268fd2b2289} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 1, should be 2: In scope SELECT arrayShingles([1, 2, 3, 4, 5]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55570) (comment: 02891_array_shingles.sql) (query 3, line 3) (in query: SELECT arrayShingles([1, 2, 3, 4, 5]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:39:28.124200 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 1, should be 2: In scope SELECT arrayShingles([1, 2, 3, 4, 5]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:39:28.270417 [ 8442 ] {dc693d57-e434-4491-ba35-484f47b1191b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 2, 3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55570) (comment: 02891_array_shingles.sql) (query 4, line 4) (in query: SELECT arrayShingles([1, 2, 3, 4, 5], 2, 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:39:28.279675 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 2, 3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:39:28.436823 [ 3931 ] {cba0016e-4efa-4e13-bb49-569b99ca658f} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 2, should be 1: In scope SELECT isConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 751, line 751) (in query: SELECT isConstant(NULL, NULL);) 2025.06.13 15:39:28.445038 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 2, should be 1: In scope SELECT isConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:28.601213 [ 8442 ] {382fd964-a09b-41ca-a7db-5d009f7dfc28} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'length' to function 'arrayShingles'. Expected: Integer, got: String: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 'str'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55570) (comment: 02891_array_shingles.sql) (query 5, line 5) (in query: SELECT arrayShingles([1, 2, 3, 4, 5], 'str');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionArrayShingles::getReturnTypeImpl(std::vector> const&) const @ 0x00000000230bf447 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:39:28.613495 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'length' to function 'arrayShingles'. Expected: Integer, got: String: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 'str'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionArrayShingles::getReturnTypeImpl(std::vector> const&) const @ 0x00000000230bf447 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:39:28.694217 [ 3931 ] {4cc68b4c-704d-45c6-b99f-7e6643ab567a} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 2, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 753, line 753) (in query: SELECT isDynamicElementInSharedData(NULL, NULL);) 2025.06.13 15:39:28.706417 [ 8442 ] {ca4fe34f-4adc-4d69-8e3d-bca898632def} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array' to function 'arrayShingles'. Expected: Array, got: Tuple(UInt8, UInt8, UInt8, UInt8, UInt8): In scope SELECT arrayShingles((1, 2, 3, 4, 5), 0). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55570) (comment: 02891_array_shingles.sql) (query 6, line 6) (in query: SELECT arrayShingles((1, 2, 3, 4, 5), 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionArrayShingles::getReturnTypeImpl(std::vector> const&) const @ 0x00000000230bf447 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:39:28.708122 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 2, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:28.716745 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array' to function 'arrayShingles'. Expected: Array, got: Tuple(UInt8, UInt8, UInt8, UInt8, UInt8): In scope SELECT arrayShingles((1, 2, 3, 4, 5), 0). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionArrayShingles::getReturnTypeImpl(std::vector> const&) const @ 0x00000000230bf447 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:39:28.834405 [ 8442 ] {094ae836-2aed-41a8-8020-58a388e5c69c} executeQuery: Code: 36. DB::Exception: Shingle argument of function arrayShingles must be a positive integer.: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 0). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55570) (comment: 02891_array_shingles.sql) (query 7, line 7) (in query: SELECT arrayShingles([1, 2, 3, 4, 5], 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000230beea7 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:39:28.843977 [ 3931 ] {b96f5bd4-18bc-4152-ba4b-5427523b9741} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 2, should be 1: In scope SELECT isFinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 754, line 754) (in query: SELECT isFinite(NULL, NULL);) 2025.06.13 15:39:28.843939 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Shingle argument of function arrayShingles must be a positive integer.: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 0). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000230beea7 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:39:28.856210 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 2, should be 1: In scope SELECT isFinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:28.880442 [ 4171 ] {5e2a88dd-68d7-470a-9e7e-8c845e521da2} executeQuery: Code: 344. DB::Exception: Partition operation ALTER TABLE MOVE PARTITION is not supported for immutable disk '03008_s3_plain_rewritable'. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55594) (comment: 03008_s3_plain_rewritable.sh) (query 1, line 2) (in query: alter table test_s3_mt move partition 0 to table test_s3_mt_dst), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871846f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5380: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000030cfba5b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4185f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:39:28.907962 [ 4171 ] {} TCPHandler: Code: 344. DB::Exception: Partition operation ALTER TABLE MOVE PARTITION is not supported for immutable disk '03008_s3_plain_rewritable'. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871846f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5380: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000030cfba5b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4185f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:39:28.960161 [ 8442 ] {aef03d66-ed7d-4530-9de2-71d56a87ddef} executeQuery: Code: 36. DB::Exception: Shingle argument of function arrayShingles must be a positive integer.: In scope SELECT arrayShingles([1, 2, 3, 4, 5], -2). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55570) (comment: 02891_array_shingles.sql) (query 8, line 8) (in query: SELECT arrayShingles([1, 2, 3, 4, 5], -2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000230beea7 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:39:28.979233 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Shingle argument of function arrayShingles must be a positive integer.: In scope SELECT arrayShingles([1, 2, 3, 4, 5], -2). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000230beea7 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:39:28.985298 [ 3931 ] {d1a651fd-26b9-446c-9de4-e22856ff526f} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 755, line 755) (in query: SELECT isIPAddressInRange(NULL, NULL);) 2025.06.13 15:39:29.000304 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:39:29.103999 [ 3931 ] {ab100023-5c51-4951-a97d-3df2a5999154} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 2, should be 1: In scope SELECT isIPv4String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 756, line 756) (in query: SELECT isIPv4String(NULL, NULL);) 2025.06.13 15:39:29.128449 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 2, should be 1: In scope SELECT isIPv4String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:29.199138 [ 8442 ] {960d2454-6d93-423c-b486-a9bac39e66c1} executeQuery: Code: 36. DB::Exception: Shingle argument of function arrayShingles must less or equal than the array length.: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 6). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55570) (comment: 02891_array_shingles.sql) (query 9, line 9) (in query: SELECT arrayShingles([1, 2, 3, 4, 5], 6);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000230bedc4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:39:29.212727 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Shingle argument of function arrayShingles must less or equal than the array length.: In scope SELECT arrayShingles([1, 2, 3, 4, 5], 6). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000230bedc4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:39:29.220668 [ 3931 ] {f1f8f7e3-38cf-4e11-9957-144f2486e3c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 2, should be 1: In scope SELECT isIPv6String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 757, line 757) (in query: SELECT isIPv6String(NULL, NULL);) 2025.06.13 15:39:29.232468 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 2, should be 1: In scope SELECT isIPv6String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:29.250356 [ 8442 ] {71c3c73e-f64a-4926-be71-c19899072a7d} executeQuery: Code: 36. DB::Exception: Shingle argument of function arrayShingles must less or equal than the array length.: In scope SELECT arrayShingles([], 1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55570) (comment: 02891_array_shingles.sql) (query 10, line 10) (in query: SELECT arrayShingles([], 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000230bedc4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:39:29.254186 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Shingle argument of function arrayShingles must less or equal than the array length.: In scope SELECT arrayShingles([], 1). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayShingles::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000230bedc4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:39:29.291257 [ 3931 ] {cc0d04e0-df34-4632-9ce7-93172ec5a419} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 2, should be 1: In scope SELECT isInfinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 758, line 758) (in query: SELECT isInfinite(NULL, NULL);) 2025.06.13 15:39:29.296817 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 2, should be 1: In scope SELECT isInfinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:29.366843 [ 3931 ] {67489279-9aa2-4e72-b98d-807a583b80f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 2, should be 1: In scope SELECT isNaN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 759, line 759) (in query: SELECT isNaN(NULL, NULL);) 2025.06.13 15:39:29.372052 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 2, should be 1: In scope SELECT isNaN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:29.428313 [ 3931 ] {c4db67be-b724-43e1-b505-1f3d71630746} executeQuery: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section: In scope SELECT NULL <=> NULL. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 760, line 760) (in query: SELECT isNotDistinctFrom(NULL, NULL);) 2025.06.13 15:39:29.458164 [ 3931 ] {} TCPHandler: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section: In scope SELECT NULL <=> NULL. (NOT_IMPLEMENTED) 2025.06.13 15:39:29.535631 [ 3931 ] {57a032b7-ec5d-43a5-ba85-4b8298191acd} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 2, should be 1: In scope SELECT isNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 761, line 761) (in query: SELECT isNotNull(NULL, NULL);) 2025.06.13 15:39:29.544169 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 2, should be 1: In scope SELECT isNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:29.660900 [ 3931 ] {7ae9df90-2bad-416d-bf92-b029d8f46eb1} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 2, should be 1: In scope SELECT isNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 762, line 762) (in query: SELECT isNull(NULL, NULL);) 2025.06.13 15:39:29.669077 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 2, should be 1: In scope SELECT isNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:29.734502 [ 3931 ] {ec5e7d95-4e63-427a-89d1-33101d1c254f} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 2, should be 1: In scope SELECT isNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 763, line 763) (in query: SELECT isNullable(NULL, NULL);) 2025.06.13 15:39:29.742774 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 2, should be 1: In scope SELECT isNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:29.799916 [ 3931 ] {6df8f0d6-a3c1-4303-9c7a-93129bc9f566} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 764, line 764) (in query: SELECT isValidJSON(NULL, NULL);) 2025.06.13 15:39:29.805982 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:29.865727 [ 3931 ] {3114ca1a-5471-48e6-9f5c-7cb4aace2e2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT isValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 765, line 765) (in query: SELECT isValidUTF8(NULL, NULL);) 2025.06.13 15:39:29.873504 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT isValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:29.914711 [ 4930 ] {353a08c2-1fea-4d2b-bc9f-5183e41d1144} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 0.00 B (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55522) (comment: 00212_long_shard_aggregate_function_uniq.sql) (query 12, line 21) (in query: SELECT Y, uniqHLL12(X) FROM (SELECT number AS X, round(toFloat32(1/(1 + (3*X*X - 7*X + 11) % 37)), 3) AS Y FROM system.numbers LIMIT 1000000) GROUP BY Y ORDER BY Y;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6ab404 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6bc5ae 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d8bba4 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d85ecd 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:29.926803 [ 4930 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 0.00 B (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6ab404 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6bc5ae 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d8bba4 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d85ecd 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:39:29.947240 [ 3931 ] {96f0b153-bbd9-4f8e-9176-46d2ddfbdb81} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 2, should be 1: In scope SELECT isZeroOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 766, line 766) (in query: SELECT isZeroOrNull(NULL, NULL);) 2025.06.13 15:39:29.952069 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 2, should be 1: In scope SELECT isZeroOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:30.269024 [ 9636 ] {343c8601-2f3a-4b31-83ce-12b1ebb18778} 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.20286.altinityantalya (altinity build)) (from [::1]:44256) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5755: DB::StorageReplicatedMergeTree::getMaxAddedBlocks() const @ 0x000000003066cab4 6. ./build_docker/./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) @ 0x000000003066e0dd 7. ./build_docker/./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) @ 0x000000003066d307 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda115e 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 10. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 11. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:39:30.282552 [ 9636 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5755: DB::StorageReplicatedMergeTree::getMaxAddedBlocks() const @ 0x000000003066cab4 6. ./build_docker/./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) @ 0x000000003066e0dd 7. ./build_docker/./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) @ 0x000000003066d307 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda115e 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 10. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 11. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:39:30.731162 [ 3931 ] {8368ae29-43c5-4ee2-a498-23a661809129} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 771, line 771) (in query: SELECT joinGet(NULL, NULL);) 2025.06.13 15:39:30.751042 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:30.843275 [ 3931 ] {9cdd2e8b-a79e-4ff0-9426-be26c90c19ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 772, line 772) (in query: SELECT joinGetOrNull(NULL, NULL);) 2025.06.13 15:39:30.866617 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:31.495864 [ 3931 ] {88b34074-edc5-445f-a13f-28cb9f91cc6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 2, should be 1: In scope SELECT keccak256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 776, line 776) (in query: SELECT keccak256(NULL, NULL);) 2025.06.13 15:39:31.501313 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 2, should be 1: In scope SELECT keccak256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:32.345394 [ 3931 ] {57329507-27c6-4c01-95e1-865ac2fc56c8} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 783, line 783) (in query: SELECT lagInFrame(NULL, NULL);) 2025.06.13 15:39:32.351340 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.13 15:39:32.545531 [ 3931 ] {c1873c87-475f-4e3d-b630-5cd421ab7f50} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 785, line 785) (in query: SELECT lastValueRespectNulls(NULL, NULL);) 2025.06.13 15:39:32.557968 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:32.797727 [ 3931 ] {44138de3-a26b-401d-8f0b-13afa5451dbb} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 787, line 787) (in query: SELECT last_value_respect_nulls(NULL, NULL);) 2025.06.13 15:39:32.808109 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:32.872855 [ 3931 ] {86d1bc31-4dbb-4484-be01-4aa969160df2} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lcase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 788, line 788) (in query: SELECT lcase(NULL, NULL);) 2025.06.13 15:39:32.877924 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lcase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:33.049488 [ 3931 ] {1cca0043-35ad-4916-aae3-4c6f29422c47} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 790, line 790) (in query: SELECT leadInFrame(NULL, NULL);) 2025.06.13 15:39:33.060563 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.13 15:39:33.943211 [ 3931 ] {1049985c-1d6d-46ac-aadb-be38c702a732} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 796, line 796) (in query: SELECT lemmatize(NULL, NULL);) 2025.06.13 15:39:33.950761 [ 3931 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:39:34.079279 [ 3931 ] {1c00bacb-b243-4795-b47a-1ea003f1fee5} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT length(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 797, line 797) (in query: SELECT length(NULL, NULL);) 2025.06.13 15:39:34.148647 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT length(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:34.260704 [ 3931 ] {bbe1bdb8-d5d6-484d-acb3-e3ae897b49fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT lengthUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 798, line 798) (in query: SELECT lengthUTF8(NULL, NULL);) 2025.06.13 15:39:34.268563 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT lengthUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:34.442942 [ 7279 ] {de55afc9-a4e6-4639-9ad1-25c6e40a538f} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48394) (comment: 00990_hasToken.sh) (query 182, line 182) (in query: CREATE TABLE IF NOT EXISTS ht (`haystack` String, `needle` String, `match` UInt8, `func` String) ENGINE = MergeTree ORDER BY haystack SETTINGS index_granularity = 32338, min_bytes_for_wide_part = 0, 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 = 31100028, compact_parts_max_bytes_to_buffer = 133792613, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 15158798, merge_max_block_size = 14292, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 146289, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 9837860705, index_granularity_bytes = 22775793, 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 = 89159, primary_key_compress_block_size = 94029, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:34.460705 [ 7279 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:35.039890 [ 8430 ] {e5ed2f81-4faa-4d48-b369-5a4cc3e565e2} executeQuery: Code: 57. DB::Exception: Table test_3.numbers_mt already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49652) (comment: 00113_shard_group_array.sql) (query 16, line 23) (in query: CREATE TABLE numbers_mt (number UInt64) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:39:35.092509 [ 8430 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.numbers_mt already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:39:35.306176 [ 3931 ] {2def71cd-6ad2-4f94-af40-ebd47797bff0} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 2, should be 1: In scope SELECT lgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 803, line 803) (in query: SELECT lgamma(NULL, NULL);) 2025.06.13 15:39:35.349584 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 2, should be 1: In scope SELECT lgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:35.576873 [ 3931 ] {6ba4f984-23c7-4828-ba72-eb219a0e3d24} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT ln(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 805, line 805) (in query: SELECT ln(NULL, NULL);) 2025.06.13 15:39:35.593114 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT ln(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:35.832022 [ 3931 ] {53c78bfb-125b-4f05-ba38-79855229ac8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT log(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 807, line 807) (in query: SELECT log(NULL, NULL);) 2025.06.13 15:39:35.861532 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT log(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:35.992745 [ 3931 ] {08c92581-b513-4088-a6e0-2d684273db78} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 2, should be 1: In scope SELECT log10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 808, line 808) (in query: SELECT log10(NULL, NULL);) 2025.06.13 15:39:36.010062 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 2, should be 1: In scope SELECT log10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:36.153656 [ 3931 ] {b7ebc512-819d-4c2f-ac1b-81613c806613} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 2, should be 1: In scope SELECT log1p(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 809, line 809) (in query: SELECT log1p(NULL, NULL);) 2025.06.13 15:39:36.184055 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 2, should be 1: In scope SELECT log1p(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:36.307301 [ 3931 ] {57ca8f43-33c7-40ff-b7b3-cdf3a97f64ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 2, should be 1: In scope SELECT log2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 810, line 810) (in query: SELECT log2(NULL, NULL);) 2025.06.13 15:39:36.344770 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 2, should be 1: In scope SELECT log2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:36.463905 [ 3931 ] {0c974c31-0fa1-4381-b20c-f576b7fff6e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 2, should be 1: In scope SELECT logTrace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 811, line 811) (in query: SELECT logTrace(NULL, NULL);) 2025.06.13 15:39:36.476441 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 2, should be 1: In scope SELECT logTrace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:36.550622 [ 3931 ] {3fe3f838-5290-4891-b361-a5a80cf95f18} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 812, line 812) (in query: SELECT lowCardinalityIndices(NULL, NULL);) 2025.06.13 15:39:36.559269 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:36.727646 [ 3931 ] {e0505bdb-4ccb-4a68-b184-27546aaa2c27} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 813, line 813) (in query: SELECT lowCardinalityKeys(NULL, NULL);) 2025.06.13 15:39:36.739550 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:36.807228 [ 3931 ] {c87461be-9ff2-4930-a178-d447abe81019} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lower(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 814, line 814) (in query: SELECT lower(NULL, NULL);) 2025.06.13 15:39:36.817080 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lower(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:36.923364 [ 9636 ] {3ee87011-59f7-478a-8902-c993bf0a521f} 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.20286.altinityantalya (altinity build)) (from [::1]:44256) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000003116d9b3 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()::operator()() const @ 0x0000000031190b54 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x0000000031190718 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003116b084 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000031154a70 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000031169ec1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb561 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 17. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:39:36.937539 [ 3931 ] {a13c727e-ff33-4157-ba7a-88c1ae1b0a5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 2, should be 1: In scope SELECT lowerUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 815, line 815) (in query: SELECT lowerUTF8(NULL, NULL);) 2025.06.13 15:39:36.939942 [ 9636 ] {} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000003116d9b3 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()::operator()() const @ 0x0000000031190b54 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x0000000031190718 8. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003116b084 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000031154a70 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000031169ec1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb561 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 17. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 18. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:39:36.954337 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 2, should be 1: In scope SELECT lowerUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:37.100008 [ 5163 ] {ac94e92d-2bf4-463c-ad74-4af523b4f811} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33960) (comment: 01732_race_condition_storage_join_long.sh) (query 2, line 3) (in query: CREATE TABLE storage_join_race (x UInt64, y UInt64) Engine = Join(ALL, FULL, x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:37.124908 [ 5163 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:38.238411 [ 3931 ] {2104e1d0-4d09-430a-a9a1-bec7b27ef9ac} executeQuery: Code: 36. DB::Exception: Map cannot have a key of type Nullable(Nothing): In scope SELECT map(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 823, line 824) (in query: SELECT map(NULL, NULL);) 2025.06.13 15:39:38.252856 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Map cannot have a key of type Nullable(Nothing): In scope SELECT map(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:39:38.444995 [ 3894 ] {6bd11fd6-9051-47ca-a2db-8b7a3bc583dd} 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.20286.altinityantalya (altinity build)) (from [::1]:34016) (comment: 01329_compare_tuple_string_constant.sql) (query 1, line 1) (in query: SELECT tuple(1) < '';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3182b 5. ./src/IO/ReadHelpers.h:204: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002c6876b0 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e257bab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0cfd28 9. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b40d7 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:39:38.450319 [ 3894 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '(' at end of stream.: while converting '' to Tuple(UInt8): In scope SELECT tuple(1) < ''. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000023b3182b 5. ./src/IO/ReadHelpers.h:204: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002c6876b0 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e257bab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0cfd28 9. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b40d7 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:39:38.577532 [ 3894 ] {b45c7265-5343-4483-bae3-4af97b5c94e6} 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.20286.altinityantalya (altinity build)) (from [::1]:34016) (comment: 01329_compare_tuple_string_constant.sql) (query 2, line 2) (in query: SELECT tuple(1) < materialize('');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c510038 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:401: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c515429 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001d0d1eb6 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b4a90 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 16. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 18. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 19. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 20. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:39:38.596369 [ 3894 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Tuple(UInt8), String because some of them are Tuple and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c510038 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:401: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c515429 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001d0d1eb6 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b4a90 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 16. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 18. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 19. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 20. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:39:38.895353 [ 3931 ] {47ade1b1-4729-4897-8368-94131c7c905c} executeQuery: Code: 43. DB::Exception: Function mapContains requires at least one argument of type Map: In scope SELECT mapContains(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 828, line 829) (in query: SELECT mapContains(NULL, NULL);) 2025.06.13 15:39:38.903732 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Function mapContains requires at least one argument of type Map: In scope SELECT mapContains(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:39:39.684798 [ 3931 ] {04d132b8-17a3-46bb-91d2-53aa29c9abdd} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 2, should be 1: In scope SELECT mapKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 835, line 836) (in query: SELECT mapKeys(NULL, NULL);) 2025.06.13 15:39:39.701848 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 2, should be 1: In scope SELECT mapKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:40.963851 [ 3931 ] {5b703fa7-2d00-40fb-bca9-4cae918b6637} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 2, should be 1: In scope SELECT mapValues(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 843, line 844) (in query: SELECT mapValues(NULL, NULL);) 2025.06.13 15:39:40.982453 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 2, should be 1: In scope SELECT mapValues(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:41.184122 [ 3931 ] {5ae20376-8f4b-4430-b387-434bd762660a} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 2, should be 1: In scope SELECT materialize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 845, line 846) (in query: SELECT materialize(NULL, NULL);) 2025.06.13 15:39:41.189515 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 2, should be 1: In scope SELECT materialize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:42.024896 [ 6234 ] {5787b5a7-70bb-46ee-9b96-2b47ebd3a567} executeQuery: Code: 36. DB::Exception: Log name 'no_such_log_and_never_will_be' does not exist. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34102) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Interpreters/SystemLog.cpp:423: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x000000002e002dff 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x000000002e2ee89e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:39:42.030377 [ 6234 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Interpreters/SystemLog.cpp:423: DB::SystemLogs::flush(bool, std::vector> const&) @ 0x000000002e002dff 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:796: DB::InterpreterSystemQuery::execute() @ 0x000000002e2ee89e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:39:45.205538 [ 6234 ] {d717cdd7-8ec4-4106-bcd0-eb85350d3a8b} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e') AS v, toTypeName(v). (UNKNOWN_SETTING) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34126) (comment: 01418_custom_settings.sql) (query 23, line 26) (in query: SELECT getSetting('custom_e') as v, toTypeName(v);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c07d5e0 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c27a727 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c27a528 7. ./build_docker/./src/Core/Settings.cpp:6484: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c17e718 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc2078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc1eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:39:45.218854 [ 6234 ] {} TCPHandler: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e') AS v, toTypeName(v). (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c07d5e0 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c27a727 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c27a528 7. ./build_docker/./src/Core/Settings.cpp:6484: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c17e718 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc2078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc1eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:39:45.356239 [ 7755 ] {b8f45037-1e5f-4ad1-ae34-26811aa16ec4} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44728) (comment: 02421_explain_subquery.sql) (query 1, line 1) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:45.384449 [ 7755 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:45.897508 [ 6234 ] {f2ae9ab9-a74a-4082-89d1-6f3ec51ed4c5} executeQuery: Code: 115. DB::Exception: Setting invalid_custom is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34126) (comment: 01418_custom_settings.sql) (query 27, line 31) (in query: SET invalid_custom = 8;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Access/AccessControl.cpp:134: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002bcc4a7c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:279: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9238 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:45.933282 [ 6234 ] {} TCPHandler: Code: 115. DB::Exception: Setting invalid_custom is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Access/AccessControl.cpp:134: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002bcc4a7c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:279: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9238 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:46.008815 [ 8099 ] {b30b8988-1446-4c97-af32-d8a2385242aa} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44708) (comment: 02810_convert_uuid_to_uint128.sql) (query 4, line 4) (in query: SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./src/Functions/FunctionsConversion.h:1716: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b0aa443 6. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f986 7. ./src/Core/callOnTypeIndex.h:286: 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&&) @ 0x000000002b02ad40 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:39:46.018114 [ 8099 ] {} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./src/Functions/FunctionsConversion.h:1716: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b0aa443 6. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f986 7. ./src/Core/callOnTypeIndex.h:286: 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&&) @ 0x000000002b02ad40 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:39:46.089379 [ 3931 ] {5b358391-dd02-494a-b0fb-eebc978f9943} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 873, line 874) (in query: SELECT minSampleSizeContinous(NULL, NULL);) 2025.06.13 15:39:46.103895 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:46.188959 [ 3931 ] {b970549d-39ed-4213-b233-84edca7ea82f} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 874, line 875) (in query: SELECT minSampleSizeContinuous(NULL, NULL);) 2025.06.13 15:39:46.189564 [ 8099 ] {16a39ed8-390e-404b-9cce-726cdc750194} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44708) (comment: 02810_convert_uuid_to_uint128.sql) (query 5, line 5) (in query: SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./src/Functions/FunctionsConversion.h:1716: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToInt128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b1080a3 6. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b0fd326 7. ./src/Core/callOnTypeIndex.h:286: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02c240 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04745e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0462c3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:39:46.211125 [ 8099 ] {} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./src/Functions/FunctionsConversion.h:1716: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToInt128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b1080a3 6. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b0fd326 7. ./src/Core/callOnTypeIndex.h:286: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02c240 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b04745e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0462c3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:39:46.213809 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:46.409903 [ 3931 ] {023fb5dc-69d2-4d9e-aedd-215515e31108} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 2, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 875, line 876) (in query: SELECT minSampleSizeConversion(NULL, NULL);) 2025.06.13 15:39:46.427753 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 2, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:47.178902 [ 6234 ] {3e5184b9-bb92-4da3-b733-92bf9dccbb11} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_f': In scope SELECT getSetting('custom_f') AS v, toTypeName(v). (UNKNOWN_SETTING) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34126) (comment: 01418_custom_settings.sql) (query 35, line 41) (in query: SELECT getSetting('custom_f') as v, toTypeName(v);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c07d5e0 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c27a727 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c27a528 7. ./build_docker/./src/Core/Settings.cpp:6484: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c17e718 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc2078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc1eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:39:47.196139 [ 6234 ] {} TCPHandler: Code: 115. DB::Exception: Unknown setting 'custom_f': In scope SELECT getSetting('custom_f') AS v, toTypeName(v). (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c07d5e0 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c27a727 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c27a528 7. ./build_docker/./src/Core/Settings.cpp:6484: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c17e718 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc2078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc1eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:39:47.449292 [ 4930 ] {ca664911-ece9-496f-b928-3c88b9e3f5d0} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44672) (comment: 03047_on_fly_mutations_projections.sql) (query 10, line 21) (in query: SELECT sum(v) FROM t_update_projections SETTINGS force_optimize_projection = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228177d 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:47.465236 [ 4930 ] {} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003228177d 6. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:47.587144 [ 3931 ] {6d72044a-df0b-4a61-9c53-0cfb606c51fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 2, should be 1: In scope SELECT monthName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 882, line 883) (in query: SELECT monthName(NULL, NULL);) 2025.06.13 15:39:47.595395 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 2, should be 1: In scope SELECT monthName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:48.052336 [ 3931 ] {58b0be6b-2654-44de-806f-1dcc03b5d565} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAllIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 885, line 886) (in query: SELECT multiFuzzyMatchAllIndices(NULL, NULL);) 2025.06.13 15:39:48.064934 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAllIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:48.159475 [ 3931 ] {a7f756d8-2bc4-4e77-aeeb-371cd55e00ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAny(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 886, line 887) (in query: SELECT multiFuzzyMatchAny(NULL, NULL);) 2025.06.13 15:39:48.224131 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAny(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:48.322008 [ 3931 ] {96f7bf2a-2ff0-4155-bc6a-c55f6d26ff63} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 887, line 888) (in query: SELECT multiFuzzyMatchAnyIndex(NULL, NULL);) 2025.06.13 15:39:48.332520 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:48.496579 [ 3931 ] {bedcdc99-2f0a-4397-b066-df00daa02e4d} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 888, line 889) (in query: SELECT multiIf(NULL, NULL);) 2025.06.13 15:39:48.515961 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:49.071880 [ 9644 ] {e1d1ba51-1a22-47fc-be96-3532d77a196c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46902) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (in query: DROP DATABASE IF EXISTS test_9no4963l SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:49.074084 [ 9644 ] {e1d1ba51-1a22-47fc-be96-3532d77a196c} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:49.535361 [ 4098 ] {f1fdfc70-b7af-403d-97a5-c0f107e34ef6} executeQuery: Code: 43. DB::Exception: Elements of array of second argument of function roundDown must be numeric type.: In scope SELECT 1 AS x, roundDown(x, []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44778) (comment: 00805_round_down.sql) (query 7, line 8) (in query: SELECT 1 as x, roundDown(x, []);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionRoundDown::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000018c3d364 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:39:49.549431 [ 4098 ] {} TCPHandler: Code: 43. DB::Exception: Elements of array of second argument of function roundDown must be numeric type.: In scope SELECT 1 AS x, roundDown(x, []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionRoundDown::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000018c3d364 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:39:49.646631 [ 4098 ] {929bc007-caad-4e34-a258-f0486cd8097e} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44778) (comment: 00805_round_down.sql) (query 8, line 9) (in query: SELECT 1 as x, roundDown(x, emptyArrayUInt8());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb202f 5. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace52eb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 14. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:39:49.653893 [ 4098 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb202f 5. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace52eb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 14. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:39:49.669976 [ 8432 ] {64588e7e-0ab9-4c09-860e-6b2a7a6abdfb} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 0, should be 2: In scope SELECT changeYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44818) (comment: 02982_changeDate.sql) (query 2, line 2) (in query: -- as changeYear, changeMonth, changeDay, changeMinute, changeSecond share the same implementation, just testing one of them SELECT changeYear();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:39:49.687845 [ 8432 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 0, should be 2: In scope SELECT changeYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:39:49.944036 [ 8432 ] {98f61890-b674-4518-bfb0-229045b3411d} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 1, should be 2: In scope SELECT changeYear(toDate('2000-01-01')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44818) (comment: 02982_changeDate.sql) (query 3, line 4) (in query: SELECT changeYear(toDate('2000-01-01'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:39:49.944035 [ 4098 ] {55d4ac73-9aa5-4cd1-9f78-43a6ad1d6270} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44778) (comment: 00805_round_down.sql) (query 9, line 10) (in query: SELECT roundDown(number, [number]) FROM system.numbers LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb202f 5. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace52eb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 14. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:39:49.951723 [ 8432 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 1, should be 2: In scope SELECT changeYear(toDate('2000-01-01')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:39:49.952763 [ 4098 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb202f 5. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace52eb 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 14. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:39:50.161922 [ 8432 ] {2a544ccd-26dd-42ce-8520-84cb6bdb56fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(toDate('2000-01-01'), 2000, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44818) (comment: 02982_changeDate.sql) (query 4, line 5) (in query: SELECT changeYear(toDate('2000-01-01'), 2000, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:39:50.169071 [ 8432 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(toDate('2000-01-01'), 2000, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:39:50.341617 [ 5112 ] {d94b3659-ef87-4f9e-8d4d-79835ff479c4} executeQuery: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55614) (comment: 03273_format_inference_create_query_s3_url.sql) (query 17, line 25) (in query: CREATE TABLE test ENGINE = S3('http://localhost:11111/test/json_data', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:39:50.361553 [ 5112 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:39:50.530035 [ 8432 ] {b3ef5149-f4eb-4283-b6b7-674880b26666} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeYear'. Expected: Date or date with time, got: UInt16: In scope SELECT changeYear(1999, 2000). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44818) (comment: 02982_changeDate.sql) (query 5, line 6) (in query: SELECT changeYear(1999, 2000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionChangeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ecc880 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:39:50.540139 [ 8432 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeYear'. Expected: Date or date with time, got: UInt16: In scope SELECT changeYear(1999, 2000). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionChangeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ecc880 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:39:50.655012 [ 8432 ] {e2d4ad2d-ae20-4032-b5af-db1caf3effed} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'value' to function 'changeYear'. Expected: Integer, got: String: In scope SELECT changeYear(toDate('2000-01-01'), 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44818) (comment: 02982_changeDate.sql) (query 6, line 7) (in query: SELECT changeYear(toDate('2000-01-01'), 'abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionChangeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ecc880 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:39:50.673947 [ 8432 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'value' to function 'changeYear'. Expected: Integer, got: String: In scope SELECT changeYear(toDate('2000-01-01'), 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionChangeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ecc880 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:39:50.770508 [ 8432 ] {d361b66b-7e09-4b52-86ff-8a64ca8ee144} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'value' to function 'changeYear'. Expected: Integer, got: Float64: In scope SELECT changeYear(toDate('2000-01-01'), 1.5). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44818) (comment: 02982_changeDate.sql) (query 7, line 8) (in query: SELECT changeYear(toDate('2000-01-01'), 1.5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionChangeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ecc880 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:39:50.784292 [ 8432 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'value' to function 'changeYear'. Expected: Integer, got: Float64: In scope SELECT changeYear(toDate('2000-01-01'), 1.5). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionChangeDate::getReturnTypeImpl(std::vector> const&) const @ 0x0000000019ecc880 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:39:51.702641 [ 5978 ] {8dbe55fb-808b-482a-9869-842cfb775b3f} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44872) (comment: 02897_alter_partition_parameters.sql) (query 2, line 3) (in query: CREATE TABLE test (`EventDate` Date) ENGINE = MergeTree PARTITION BY toMonday(EventDate) ORDER BY tuple() SETTINGS index_granularity = 36441, min_bytes_for_wide_part = 698134415, 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 = 425174861, compact_parts_max_granules_to_buffer = 232, compact_parts_merge_max_bytes_to_prefetch_part = 991933, merge_max_block_size = 22293, old_parts_lifetime = 54., 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 = 13457901, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 78960, primary_key_compress_block_size = 96838, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:51.719285 [ 5978 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:53.550877 [ 8101 ] {45c5b34a-c16b-4b19-b8d5-28f839c22571} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 0, should be 1: In scope SELECT seriesPeriodDetectFFT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44864) (comment: 02813_series_period_detect.sql) (query 15, line 19) (in query: SELECT seriesPeriodDetectFFT();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:39:53.613866 [ 8101 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 0, should be 1: In scope SELECT seriesPeriodDetectFFT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:39:53.624847 [ 3931 ] {bd49d028-f0f8-41fa-9fe5-5bb3d67b9185} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 2, should be 1: In scope SELECT negate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 915, line 916) (in query: SELECT negate(NULL, NULL);) 2025.06.13 15:39:53.633388 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 2, should be 1: In scope SELECT negate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:53.720525 [ 3931 ] {2f0d5fd3-3cda-4a38-8a9b-991b31b3f006} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 916, line 917) (in query: SELECT neighbor(NULL, NULL);) 2025.06.13 15:39:53.736307 [ 3931 ] {} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:39:53.802230 [ 8101 ] {06040dae-8ef9-4e2c-bb7d-df41cf7a77b2} executeQuery: Code: 44. DB::Exception: Illegal column Array(Nothing) of first argument of function seriesPeriodDetectFFT: In scope SELECT seriesPeriodDetectFFT([]). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44864) (comment: 02813_series_period_detect.sql) (query 16, line 20) (in query: SELECT seriesPeriodDetectFFT([]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionSeriesPeriodDetectFFT::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000207bbd73 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:39:53.833451 [ 8101 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column Array(Nothing) of first argument of function seriesPeriodDetectFFT: In scope SELECT seriesPeriodDetectFFT([]). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionSeriesPeriodDetectFFT::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000207bbd73 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:39:53.900579 [ 8101 ] {5287c560-5cca-48c8-a409-b88206cb5d81} executeQuery: Code: 44. DB::Exception: Illegal column Array(Nullable(Nothing)) of first argument of function seriesPeriodDetectFFT: In scope SELECT seriesPeriodDetectFFT([NULL, NULL, NULL]). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44864) (comment: 02813_series_period_detect.sql) (query 17, line 21) (in query: SELECT seriesPeriodDetectFFT([NULL, NULL, NULL]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionSeriesPeriodDetectFFT::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000207bbd73 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:39:53.924543 [ 8101 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column Array(Nullable(Nothing)) of first argument of function seriesPeriodDetectFFT: In scope SELECT seriesPeriodDetectFFT([NULL, NULL, NULL]). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionSeriesPeriodDetectFFT::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000207bbd73 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:39:54.033194 [ 8101 ] {cbedb15e-6a23-4548-bd9c-ace7d92abdaa} executeQuery: Code: 44. DB::Exception: Illegal column Array(Nullable(UInt8)) of first argument of function seriesPeriodDetectFFT: In scope SELECT seriesPeriodDetectFFT([10, 20, 30, 10, 202, 30, NULL]). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44864) (comment: 02813_series_period_detect.sql) (query 18, line 22) (in query: SELECT seriesPeriodDetectFFT([10, 20, 30, 10, 202, 30, NULL]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionSeriesPeriodDetectFFT::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000207bbd73 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:39:54.041349 [ 8101 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column Array(Nullable(UInt8)) of first argument of function seriesPeriodDetectFFT: In scope SELECT seriesPeriodDetectFFT([10, 20, 30, 10, 202, 30, NULL]). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionSeriesPeriodDetectFFT::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000207bbd73 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:39:54.179714 [ 3931 ] {ca439646-8f59-4920-9793-7693d2b58bc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 2, should be 1: In scope SELECT netloc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 918, line 919) (in query: SELECT netloc(NULL, NULL);) 2025.06.13 15:39:54.186723 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 2, should be 1: In scope SELECT netloc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:54.777050 [ 8101 ] {08d10245-3d58-4042-a64d-da5cf1501c17} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49686) (comment: 02315_readonly_create_function.sh) (query 1, line 1) (in query: CREATE FUNCTION test_function AS (x) -> x + 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4a216 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd49055 6. ./build_docker/./src/Access/ContextAccess.cpp:775: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002bd58aa2 7. ./build_docker/./src/Access/ContextAccess.cpp:827: bool DB::ContextAccess::checkAccessImpl(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002bd1bb89 8. ./src/Access/ContextAccess.h:261: void DB::Context::checkAccessImpl(DB::AccessRightsElements const&) const @ 0x000000002d4bb5a7 9. ./build_docker/./src/Interpreters/InterpreterCreateFunctionQuery.cpp:46: DB::InterpreterCreateFunctionQuery::execute() @ 0x000000002e3632f1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:54.789555 [ 8101 ] {} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4a216 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd49055 6. ./build_docker/./src/Access/ContextAccess.cpp:775: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002bd58aa2 7. ./build_docker/./src/Access/ContextAccess.cpp:827: bool DB::ContextAccess::checkAccessImpl(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002bd1bb89 8. ./src/Access/ContextAccess.h:261: void DB::Context::checkAccessImpl(DB::AccessRightsElements const&) const @ 0x000000002d4bb5a7 9. ./build_docker/./src/Interpreters/InterpreterCreateFunctionQuery.cpp:46: DB::InterpreterCreateFunctionQuery::execute() @ 0x000000002e3632f1 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:55.293790 [ 8442 ] {b117bcdf-6226-4fba-ad04-a2d38c5f42d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 2, should be 1: In scope SELECT BLAKE3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 4, line 4) (in query: SELECT BLAKE3(NULL, NULL);) 2025.06.13 15:39:55.317012 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 2, should be 1: In scope SELECT BLAKE3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:55.484822 [ 8442 ] {b1ca8f6e-df1f-4fd3-a161-4ce7eb0b91d6} executeQuery: Code: 43. DB::Exception: Second argument to CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 5, line 5) (in query: SELECT CAST(NULL, NULL);) 2025.06.13 15:39:55.498568 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:39:55.605932 [ 8442 ] {7b628f24-984e-4e92-bf87-518c5a9bead7} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 6, line 6) (in query: SELECT CHARACTER_LENGTH(NULL, NULL);) 2025.06.13 15:39:55.619553 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:55.726848 [ 8442 ] {99eedf61-ae53-4687-a804-618f502e0f34} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 7, line 7) (in query: SELECT CHAR_LENGTH(NULL, NULL);) 2025.06.13 15:39:55.833501 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:56.389915 [ 9636 ] {8d1b6cd4-2d5c-4a1b-9493-475218e626fb} executeQuery: Code: 179. DB::Exception: Multiple expressions 2 AS value and 1 AS value for alias value. In scope SELECT 1 AS value, 2 AS value. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49662) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 9, line 17) (in query: SELECT 1 AS value, 2 AS value;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5721: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfbe9c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:56.402359 [ 9636 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions 2 AS value and 1 AS value for alias value. In scope SELECT 1 AS value, 2 AS value. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5721: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfbe9c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:56.402841 [ 8442 ] {8d1d4a83-bdd0-4895-a080-b92a2150c563} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 2, should be 1: In scope SELECT CRC32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 10, line 10) (in query: SELECT CRC32(NULL, NULL);) 2025.06.13 15:39:56.418602 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 2, should be 1: In scope SELECT CRC32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:56.534438 [ 9636 ] {b619af6f-3962-403c-b525-6ffcd5ea9bcb} executeQuery: Code: 179. DB::Exception: Multiple expressions 2 AS value and _CAST(2, 'UInt16') for alias value. In scope SELECT 1 + 1 AS value, 2 AS value. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49662) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 10, line 18) (in query: SELECT plus(1, 1) AS value, 2 AS value;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5721: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfbe9c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:56.542078 [ 9636 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions 2 AS value and _CAST(2, 'UInt16') for alias value. In scope SELECT 1 + 1 AS value, 2 AS value. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5721: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfbe9c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:56.559206 [ 8442 ] {8e23ed0e-9225-4780-9578-5b19531d9e9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 2, should be 1: In scope SELECT CRC32IEEE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 11, line 11) (in query: SELECT CRC32IEEE(NULL, NULL);) 2025.06.13 15:39:56.566832 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 2, should be 1: In scope SELECT CRC32IEEE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:56.711454 [ 8442 ] {b71d3dd3-9869-4621-84bc-026b901efe6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 2, should be 1: In scope SELECT CRC64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 12, line 12) (in query: SELECT CRC64(NULL, NULL);) 2025.06.13 15:39:56.721979 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 2, should be 1: In scope SELECT CRC64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:56.725602 [ 9636 ] {5cdae36f-f043-4c66-b31d-a8544a3c6d8b} executeQuery: Code: 179. DB::Exception: Multiple expressions 1 AS subquery and (SELECT 1) AS subquery for alias subquery. In scope SELECT (SELECT 1) AS subquery, 1 AS subquery. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49662) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 11, line 19) (in query: SELECT (SELECT 1) AS subquery, 1 AS subquery;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5721: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfbe9c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:56.731494 [ 9636 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions 1 AS subquery and (SELECT 1) AS subquery for alias subquery. In scope SELECT (SELECT 1) AS subquery, 1 AS subquery. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5721: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfbe9c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:56.777821 [ 4930 ] {1b3783ca-44ad-43cb-9cb7-9f5a4b169679} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33464) (comment: 03199_merge_filters_bug.sql) (in query: DROP DATABASE IF EXISTS test_wruu5v7z SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:39:56.788244 [ 4930 ] {1b3783ca-44ad-43cb-9cb7-9f5a4b169679} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:39:56.798829 [ 8442 ] {eb40b080-ad90-41ce-a81b-e8e0f1fdc46b} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT DATABASE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 13, line 13) (in query: SELECT DATABASE(NULL, NULL);) 2025.06.13 15:39:56.813618 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT DATABASE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:56.932797 [ 9636 ] {a2e009ca-5d8e-40a0-abdd-bef42820cf14} executeQuery: Code: 179. DB::Exception: Multiple expressions x -> (x + 2) AS lambda and x -> (x + 1) AS lambda for alias lambda. In scope WITH x -> (x + 1) AS lambda, (x -> (x + 2)) AS lambda SELECT lambda(1). (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49662) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 12, line 20) (in query: WITH x -> x + 1 AS lambda, x -> x + 2 AS lambda SELECT lambda(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5738: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfc1dc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:56.940948 [ 9636 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions x -> (x + 2) AS lambda and x -> (x + 1) AS lambda for alias lambda. In scope WITH x -> (x + 1) AS lambda, (x -> (x + 2)) AS lambda SELECT lambda(1). (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5738: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfc1dc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.060004 [ 9636 ] {b60d8b34-459b-4ce9-b400-a456606f5dbb} executeQuery: Code: 179. DB::Exception: Multiple expressions (SELECT 1) AS lambda and x -> (x + 1) AS lambda for alias lambda. In scope WITH x -> (x + 1) AS lambda SELECT (SELECT 1) AS lambda. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49662) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 13, line 21) (in query: WITH x -> x + 1 AS lambda SELECT (SELECT 1) AS lambda;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5738: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfc1dc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.078824 [ 9636 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions (SELECT 1) AS lambda and x -> (x + 1) AS lambda for alias lambda. In scope WITH x -> (x + 1) AS lambda SELECT (SELECT 1) AS lambda. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5738: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfc1dc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.132236 [ 8099 ] {} TCPHandler: Code: 702. DB::Exception: Client info's client_name does not match: ClickHouse client not equal to Hacker client. (CLIENT_INFO_DOES_NOT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/Server/TCPHandler.cpp:219: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316bfb48 6. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 7. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.169404 [ 9636 ] {be059409-b2d9-4b03-9d74-48975774ef14} executeQuery: Code: 179. DB::Exception: Multiple expressions 1 AS lambda and x -> (x + 1) AS lambda for alias lambda. In scope WITH x -> (x + 1) AS lambda SELECT 1 AS lambda. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49662) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 14, line 22) (in query: WITH x -> x + 1 AS lambda SELECT 1 AS lambda;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5738: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfc1dc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.193800 [ 9636 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions 1 AS lambda and x -> (x + 1) AS lambda for alias lambda. In scope WITH x -> (x + 1) AS lambda SELECT 1 AS lambda. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5738: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfc1dc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.197930 [ 8099 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 58. Bytes expected: 83. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb202f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b28973 6. ./build_docker/./src/Server/TCPHandler.cpp:1829: DB::TCPHandler::processUnexpectedHello() @ 0x00000000316bd358 7. ./build_docker/./src/Server/TCPHandler.cpp:891: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b67b8 8. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.313070 [ 2862 ] {} TCPHandler: Code: 702. DB::Exception: Client info's version does not match: 20.13.0 (54443) not equal to 16.13.1 (54443). (CLIENT_INFO_DOES_NOT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Server/TCPHandler.cpp:227: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c396e 6. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 7. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.314857 [ 2862 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 58. Bytes expected: 83. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb202f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b28973 6. ./build_docker/./src/Server/TCPHandler.cpp:1829: DB::TCPHandler::processUnexpectedHello() @ 0x00000000316bd358 7. ./build_docker/./src/Server/TCPHandler.cpp:891: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b67b8 8. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.443181 [ 9636 ] {9803cbf5-89b5-4cb3-8121-73a60c441456} executeQuery: Code: 179. DB::Exception: Multiple expressions test_9.test_table.value and test_9.test_table.id for alias value. In scope SELECT id AS value, value AS value FROM test_table. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49662) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 15, line 23) (in query: SELECT id AS value, value AS value FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5721: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfbe9c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.455723 [ 9636 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions test_9.test_table.value and test_9.test_table.id for alias value. In scope SELECT id AS value, value AS value FROM test_table. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5721: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfbe9c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.538356 [ 9636 ] {621e8092-7947-415f-a3c4-cb62649eafd2} executeQuery: Code: 179. DB::Exception: Multiple expressions test_9.test_table.value and test_9.test_table.id for alias value_1. In scope SELECT id AS value_1, value AS value_1 FROM test_table. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49662) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 16, line 24) (in query: SELECT id AS value_1, value AS value_1 FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5721: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfbe9c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.555118 [ 9636 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions test_9.test_table.value and test_9.test_table.id for alias value_1. In scope SELECT id AS value_1, value AS value_1 FROM test_table. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5721: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfbe9c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.673089 [ 9636 ] {5dcfbf63-ef75-442d-93d1-eb907b440ffa} executeQuery: Code: 179. DB::Exception: Multiple expressions id + 1 AS value and test_9.test_table.id for alias value. In scope SELECT id AS value, id + 1 AS value FROM test_table. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49662) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 17, line 25) (in query: SELECT id AS value, (id + 1) AS value FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5721: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfbe9c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.682317 [ 9636 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions id + 1 AS value and test_9.test_table.id for alias value. In scope SELECT id AS value, id + 1 AS value FROM test_table. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x000000002cc5bdef 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5721: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfbe9c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:39:57.896583 [ 3931 ] {dcf52b4a-f953-474e-afd2-01e68c61af91} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 940, line 941) (in query: SELECT nonNegativeDerivative(NULL, NULL);) 2025.06.13 15:39:57.911946 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.13 15:39:58.025990 [ 3931 ] {b3e359bb-1d20-4eb8-a6f3-45e136db16fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT normL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 941, line 942) (in query: SELECT normL1(NULL, NULL);) 2025.06.13 15:39:58.038356 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT normL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:58.139514 [ 3931 ] {186448ab-49f5-42c7-b0db-9143840116dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT normL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 942, line 943) (in query: SELECT normL2(NULL, NULL);) 2025.06.13 15:39:58.156580 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT normL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:58.258769 [ 3931 ] {fa928126-351b-4407-ac1b-21fbc131a14f} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT normL2Squared(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 943, line 944) (in query: SELECT normL2Squared(NULL, NULL);) 2025.06.13 15:39:58.267463 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT normL2Squared(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:58.334644 [ 8442 ] {a1eef181-f963-4823-8592-e899436da97b} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 22, line 22) (in query: SELECT FORMAT_BYTES(NULL, NULL);) 2025.06.13 15:39:58.342680 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:58.360950 [ 3931 ] {7174e85e-d983-4a89-88a2-b359681a9c34} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT normLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 944, line 945) (in query: SELECT normLinf(NULL, NULL);) 2025.06.13 15:39:58.364610 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT normLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:58.484264 [ 8442 ] {3db00d52-9464-47b5-b60c-0f484075029a} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT FQDN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 23, line 23) (in query: SELECT FQDN(NULL, NULL);) 2025.06.13 15:39:58.502145 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT FQDN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:58.617588 [ 8442 ] {b96c7e73-4736-4de4-a9df-888b341560c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT FROM_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 24, line 24) (in query: SELECT FROM_BASE64(NULL, NULL);) 2025.06.13 15:39:58.632458 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT FROM_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:58.695149 [ 3931 ] {a17f5634-09bc-457c-8ad1-cc537f8d7f5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 946, line 947) (in query: SELECT normalizeL1(NULL, NULL);) 2025.06.13 15:39:58.703264 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:58.747171 [ 8442 ] {164eea8b-b97d-4121-830a-2be80cb39ae2} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT FROM_DAYS(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 25, line 25) (in query: SELECT FROM_DAYS(NULL, NULL);) 2025.06.13 15:39:58.759499 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT FROM_DAYS(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:58.771280 [ 3931 ] {d8c8b49f-eee3-443b-b2cc-5c9265ee95a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 947, line 948) (in query: SELECT normalizeL2(NULL, NULL);) 2025.06.13 15:39:58.798377 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:58.918322 [ 3931 ] {90d24c56-c9ed-4c11-8995-3230d7d585d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT normalizeLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 948, line 949) (in query: SELECT normalizeLinf(NULL, NULL);) 2025.06.13 15:39:58.927355 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT normalizeLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:59.147750 [ 8442 ] {2672ec07-54dd-4a39-a498-ccca556ddf35} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET6_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 28, line 28) (in query: SELECT INET6_ATON(NULL, NULL);) 2025.06.13 15:39:59.152887 [ 9636 ] {a9b2a86b-7721-42a8-8edc-e7934cd1722d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49818) (comment: 01514_parallel_formatting.sql) (query 6, line 8) (in query: insert into tsv(a) select number from numbers(10000000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000031b5395d 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000031b51796 9. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x0000000031b54a11 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:146: DB::IOutputFormat::write(DB::Block const&) @ 0x000000003184344b 11. ./build_docker/./src/Storages/StorageFile.cpp:1840: DB::StorageFileSink::consume(DB::Chunk&) @ 0x00000000303fdda7 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f67cf7 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:39:59.173856 [ 3931 ] {48510b46-144b-4f62-a560-106324effea1} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 2, should be 1: In scope SELECT normalizeQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 950, line 951) (in query: SELECT normalizeQuery(NULL, NULL);) 2025.06.13 15:39:59.181538 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 2, should be 1: In scope SELECT normalizeQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:59.205182 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET6_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:59.260314 [ 3931 ] {a42da669-e5bc-47fd-b14c-ec18e710620c} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 951, line 952) (in query: SELECT normalizeQueryKeepNames(NULL, NULL);) 2025.06.13 15:39:59.268480 [ 8442 ] {17539798-5f39-44e8-b97d-2da1f6ec1da2} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT INET6_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 29, line 29) (in query: SELECT INET6_NTOA(NULL, NULL);) 2025.06.13 15:39:59.278627 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:59.280625 [ 9636 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000031b5395d 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000031b51796 9. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x0000000031b54a11 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:146: DB::IOutputFormat::write(DB::Block const&) @ 0x000000003184344b 11. ./build_docker/./src/Storages/StorageFile.cpp:1840: DB::StorageFileSink::consume(DB::Chunk&) @ 0x00000000303fdda7 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f67cf7 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:39:59.290774 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT INET6_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:59.348874 [ 3931 ] {f1efc323-be34-4441-820d-32f0b2cbaaa0} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 952, line 953) (in query: SELECT normalizeUTF8NFC(NULL, NULL);) 2025.06.13 15:39:59.356355 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:59.448167 [ 8442 ] {fa6103d5-6262-4b02-b449-bbf7f585f8a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 30, line 30) (in query: SELECT INET_ATON(NULL, NULL);) 2025.06.13 15:39:59.468325 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:59.496678 [ 3931 ] {b6d6db64-018f-46a1-a35b-292b5704ec25} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 953, line 954) (in query: SELECT normalizeUTF8NFD(NULL, NULL);) 2025.06.13 15:39:59.505753 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:59.545739 [ 8442 ] {ffd8f8a1-c9a9-44d4-a623-f2788be30948} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT INET_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 31, line 31) (in query: SELECT INET_NTOA(NULL, NULL);) 2025.06.13 15:39:59.567777 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT INET_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:59.687465 [ 3931 ] {7635c029-cb8c-4609-bfed-8e60a197214d} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 954, line 955) (in query: SELECT normalizeUTF8NFKC(NULL, NULL);) 2025.06.13 15:39:59.694549 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:59.854094 [ 5110 ] {93c23aea-f843-4e80-9945-d2d142059b09} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49836) (comment: 02882_primary_key_index_in_function_different_types.sql) (query 4, line 10) (in query: set enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:59.854240 [ 3931 ] {155aca47-59fc-4178-a3e8-5d8acf7c0ed1} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 955, line 956) (in query: SELECT normalizeUTF8NFKD(NULL, NULL);) 2025.06.13 15:39:59.861337 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:39:59.862485 [ 5110 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:39:59.962651 [ 3931 ] {f6cd33d7-8c0b-411b-bdb2-a8c608aec2d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 956, line 957) (in query: SELECT normalizedQueryHash(NULL, NULL);) 2025.06.13 15:40:00.053789 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:00.058369 [ 8442 ] {26e0e0d7-07fc-41b9-bb92-b54ce0cbe1ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 33, line 33) (in query: SELECT IPv4NumToString(NULL, NULL);) 2025.06.13 15:40:00.081445 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:00.173148 [ 3931 ] {642fdfed-ccd0-4d15-bffc-0e0255eb19be} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 957, line 958) (in query: SELECT normalizedQueryHashKeepNames(NULL, NULL);) 2025.06.13 15:40:00.187178 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:00.227962 [ 8442 ] {9aa0655a-1139-4d06-b184-e20e25ca3ade} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 34, line 34) (in query: SELECT IPv4NumToStringClassC(NULL, NULL);) 2025.06.13 15:40:00.245654 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:00.388818 [ 3931 ] {86358277-e6dc-4404-9b9b-99dbd157cabc} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 2, should be 1: In scope SELECT not(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 958, line 959) (in query: SELECT not(NULL, NULL);) 2025.06.13 15:40:00.399997 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 2, should be 1: In scope SELECT not(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:00.499516 [ 8442 ] {1b8c94c8-1238-40a5-82a0-931549ef1628} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 35, line 35) (in query: SELECT IPv4StringToNum(NULL, NULL);) 2025.06.13 15:40:00.507164 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:00.518382 [ 3931 ] {142d2ec1-08f3-4735-8b51-da8913ee044d} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 2, should be 1: In scope SELECT notEmpty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 959, line 960) (in query: SELECT notEmpty(NULL, NULL);) 2025.06.13 15:40:00.624649 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 2, should be 1: In scope SELECT notEmpty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:00.718985 [ 8442 ] {ec60fe81-7656-44bf-a1ff-53ce6a365ab4} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 36, line 36) (in query: SELECT IPv4StringToNumOrDefault(NULL, NULL);) 2025.06.13 15:40:00.763123 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:00.877527 [ 8442 ] {3742c717-cb8e-406e-80be-535ca27d594c} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 37, line 37) (in query: SELECT IPv4StringToNumOrNull(NULL, NULL);) 2025.06.13 15:40:00.883030 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:00.979164 [ 8442 ] {64550952-34f3-425a-bcb4-ab0122f13221} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 2, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 38, line 38) (in query: SELECT IPv4ToIPv6(NULL, NULL);) 2025.06.13 15:40:01.024996 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 2, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:01.381191 [ 8442 ] {2a1ed550-b1d5-4fcb-a7fe-b9982d502711} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv6NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 40, line 40) (in query: SELECT IPv6NumToString(NULL, NULL);) 2025.06.13 15:40:01.400653 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv6NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:01.571089 [ 8442 ] {534ef042-f760-490f-b90b-55e4b489d099} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 41, line 41) (in query: SELECT IPv6StringToNum(NULL, NULL);) 2025.06.13 15:40:01.585671 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:01.696632 [ 8442 ] {5068db8c-7d54-4615-9086-ba0bdb2a62a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 42, line 42) (in query: SELECT IPv6StringToNumOrDefault(NULL, NULL);) 2025.06.13 15:40:01.727217 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:01.838098 [ 8442 ] {9716b301-18ae-462e-a082-7e271c9d821b} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 43, line 43) (in query: SELECT IPv6StringToNumOrNull(NULL, NULL);) 2025.06.13 15:40:01.891309 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:01.990191 [ 8442 ] {6e8ad4fa-7a9b-4261-b3b8-1b5a162294b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 2, should be 1: In scope SELECT JSONAllPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 44, line 44) (in query: SELECT JSONAllPaths(NULL, NULL);) 2025.06.13 15:40:01.994227 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 2, should be 1: In scope SELECT JSONAllPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:01.996087 [ 8101 ] {acd65750-c824-46ba-99bc-d04e215b762e} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_41tvivz0.minmax_idx (4fb2389c-301d-4b1c-884f-effa48f565cf)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49766) (comment: 00836_indices_alter_replicated_zookeeper_long.sql) (query 8, line 24) (in query: INSERT INTO minmax_idx VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:40:02.012302 [ 8101 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_41tvivz0.minmax_idx (4fb2389c-301d-4b1c-884f-effa48f565cf)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:40:02.122925 [ 8442 ] {35040160-c950-4544-b7a9-a5c02c751068} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 45, line 45) (in query: SELECT JSONAllPathsWithTypes(NULL, NULL);) 2025.06.13 15:40:02.133348 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:02.194394 [ 7279 ] {5fd7c1fc-3374-4e46-a978-042989e375be} executeQuery: Code: 497. DB::Exception: user03247_1_test_d5ox5kek_24847: Not enough privileges. To execute this query, it's necessary to have the grant CREATE USER ON foobar. (ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49940) (comment: 03274_precise_alter_user_grants.sh) (query 1, line 1) (in query: CREATE USER foobar), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4d268 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd4bf01 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x000000002bd4b299 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>) const @ 0x000000002bd17766 8. ./src/Access/ContextAccess.h:255: DB::InterpreterCreateUserQuery::execute() @ 0x000000002f96bf84 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:02.219469 [ 7279 ] {} TCPHandler: Code: 497. DB::Exception: user03247_1_test_d5ox5kek_24847: Not enough privileges. To execute this query, it's necessary to have the grant CREATE USER ON foobar. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4d268 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd4bf01 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x000000002bd4b299 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>) const @ 0x000000002bd17766 8. ./src/Access/ContextAccess.h:255: DB::InterpreterCreateUserQuery::execute() @ 0x000000002f96bf84 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:02.233115 [ 8442 ] {df6f1402-2163-4350-89cd-1bcd164d4ef7} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSONArrayLength(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 46, line 46) (in query: SELECT JSONArrayLength(NULL, NULL);) 2025.06.13 15:40:02.237799 [ 9642 ] {2dbe8dd4-2c9b-4156-8263-a2f74b0807a2} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_41tvivz0.minmax_idx (4fb2389c-301d-4b1c-884f-effa48f565cf)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33548) (comment: 00836_indices_alter_replicated_zookeeper_long.sql) (in query: DROP DATABASE IF EXISTS test_41tvivz0 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:40:02.247539 [ 9642 ] {2dbe8dd4-2c9b-4156-8263-a2f74b0807a2} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_41tvivz0.minmax_idx (4fb2389c-301d-4b1c-884f-effa48f565cf)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:02.251375 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSONArrayLength(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:02.362797 [ 8442 ] {99226865-f311-49ed-8411-034238fe7e95} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 47, line 47) (in query: SELECT JSONDynamicPaths(NULL, NULL);) 2025.06.13 15:40:02.372093 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:02.382161 [ 4098 ] {0d5ff3bf-6008-4165-a4f4-9cca8a59aeb3} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49948) (comment: 01825_type_json_in_array.sql) (query 1, line 3) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:02.395379 [ 4098 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:02.583512 [ 8442 ] {43b5ffea-0deb-4bfd-b608-2acfbf17d887} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 48, line 48) (in query: SELECT JSONDynamicPathsWithTypes(NULL, NULL);) 2025.06.13 15:40:02.591619 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:02.669437 [ 8442 ] {f423240a-1e00-4349-b297-7fc217e72af3} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 49, line 49) (in query: SELECT JSONExtract(NULL, NULL);) 2025.06.13 15:40:02.687236 [ 8442 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL). (ILLEGAL_COLUMN) 2025.06.13 15:40:02.692245 [ 3931 ] {b3a15081-b8b7-4d70-82a3-9a0801e6b28b} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 970, line 971) (in query: SELECT now(NULL, NULL);) 2025.06.13 15:40:02.696524 [ 8430 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:02.703348 [ 8430 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:40:02.708747 [ 9643 ] {6523b616-b33f-4b52-bf5a-08c200ce5c3c} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49858) (comment: 00857_global_joinsavel_table_alias.sql) (query 9, line 25) (in query: SELECT t2.name FROM remote('127.0.0.2', currentDatabase(), 'local_table') AS t1 LEFT JOIN test_czg008nh.other_table AS t2 ON t1.oth_id = t2.id ORDER BY t2.name ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:40:02.720109 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:02.731784 [ 9643 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:40:03.091504 [ 9642 ] {2df28207-4858-4b57-9878-230df45d439e} 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.20286.altinityantalya (altinity build)) (from [::1]:49962) (comment: 03352_allow_suspicious_ttl.sql) (query 3, line 8) (in query: -- Create CREATE TABLE replicated_ttl_00933 (a Int32, d DateTime) ENGINE=ReplicatedMergeTree('/clickhouse/tables/{database}/test_ttl_00933', 'r1') ORDER BY a PARTITION BY tuple() TTL now() + INTERVAL 1 second;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:03.109639 [ 7279 ] {6b9d7d5c-d330-483f-817a-a195bf2adbbc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33560) (comment: 00857_global_joinsavel_table_alias.sql) (in query: DROP DATABASE IF EXISTS test_czg008nh SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:40:03.110440 [ 9642 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:03.127563 [ 7279 ] {6b9d7d5c-d330-483f-817a-a195bf2adbbc} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:03.231421 [ 3931 ] {14843903-07b8-4bb0-8a15-219ebd7249db} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 973, line 974) (in query: SELECT nth_value(NULL, NULL);) 2025.06.13 15:40:03.259833 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.13 15:40:03.265201 [ 8099 ] {5fcfd454-6adf-410d-a9be-ddbcb7ced929} executeQuery: Code: 497. DB::Exception: user03247_2_test_d5ox5kek_7541: Not enough privileges. To execute this query, it's necessary to have the grant ALTER USER ON user03247_3_test_d5ox5kek_5993. (ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58004) (comment: 03274_precise_alter_user_grants.sh) (query 1, line 1) (in query: ALTER USER user03247_3_test_d5ox5kek_5993 IDENTIFIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4d268 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd4bf01 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x000000002bd4b299 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>) const @ 0x000000002bd17766 8. ./src/Access/ContextAccess.h:255: DB::InterpreterCreateUserQuery::execute() @ 0x000000002f96bf84 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:03.279166 [ 8099 ] {} TCPHandler: Code: 497. DB::Exception: user03247_2_test_d5ox5kek_7541: Not enough privileges. To execute this query, it's necessary to have the grant ALTER USER ON user03247_3_test_d5ox5kek_5993. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4d268 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd4bf01 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x000000002bd4b299 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>) const @ 0x000000002bd17766 8. ./src/Access/ContextAccess.h:255: DB::InterpreterCreateUserQuery::execute() @ 0x000000002f96bf84 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:03.352310 [ 3931 ] {d46d3001-56dc-4444-81e2-2a3e1e5949d4} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 974, line 975) (in query: SELECT ntile(NULL, NULL);) 2025.06.13 15:40:03.377643 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:03.649489 [ 8442 ] {70b0599a-d6c1-4849-8fb1-2c72e94e453a} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 55, line 55) (in query: SELECT JSONExtractKeysAndValues(NULL, NULL);) 2025.06.13 15:40:03.662154 [ 8442 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL). (ILLEGAL_COLUMN) 2025.06.13 15:40:04.359070 [ 9642 ] {8688be16-f202-4766-a7bb-dc4eaca6a5bd} executeQuery: Code: 497. DB::Exception: user03247_3_test_d5ox5kek_5993: Not enough privileges. To execute this query, it's necessary to have the grant ALTER USER ON user03247_2_test_d5ox5kek_7541. (ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58084) (comment: 03274_precise_alter_user_grants.sh) (query 1, line 1) (in query: ALTER USER user03247_2_test_d5ox5kek_7541 IDENTIFIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4d268 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd4bf01 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x000000002bd4b299 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>) const @ 0x000000002bd17766 8. ./src/Access/ContextAccess.h:255: DB::InterpreterCreateUserQuery::execute() @ 0x000000002f96bf84 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:04.373586 [ 9642 ] {} TCPHandler: Code: 497. DB::Exception: user03247_3_test_d5ox5kek_5993: Not enough privileges. To execute this query, it's necessary to have the grant ALTER USER ON user03247_2_test_d5ox5kek_7541. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4d268 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd4bf01 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x000000002bd4b299 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>) const @ 0x000000002bd17766 8. ./src/Access/ContextAccess.h:255: DB::InterpreterCreateUserQuery::execute() @ 0x000000002f96bf84 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:05.119170 [ 8442 ] {47c22bc0-ccc9-4340-83cc-04ceee127185} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 64, line 64) (in query: SELECT JSONSharedDataPaths(NULL, NULL);) 2025.06.13 15:40:05.170700 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:05.287777 [ 8442 ] {42c1fecf-2bfe-4e40-92b2-f63f481fa8ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 65, line 65) (in query: SELECT JSONSharedDataPathsWithTypes(NULL, NULL);) 2025.06.13 15:40:05.359303 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:05.626215 [ 4098 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:05.628410 [ 4098 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:40:05.642435 [ 8442 ] {fbab3661-2b7c-44c8-9158-7dec26f5bbd4} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 67, line 67) (in query: SELECT JSON_ARRAY_LENGTH(NULL, NULL);) 2025.06.13 15:40:05.671754 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:06.309141 [ 3894 ] {98c6cfbf-e588-4051-b4df-25c3182b3d54} executeQuery: Code: 60. DB::Exception: Table test_la5p8on0.t_json_16 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58186) (comment: 01825_type_json_16.sh) (query 1, line 1) (in query: INSERT INTO t_json_16 FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:06.341280 [ 3894 ] {} TCPHandler: Code: 60. DB::Exception: Table test_la5p8on0.t_json_16 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:06.720688 [ 8442 ] {c1c32c15-9471-474e-9b5d-f047cbc112ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT L1Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 72, line 72) (in query: SELECT L1Norm(NULL, NULL);) 2025.06.13 15:40:06.740374 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT L1Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:06.939081 [ 8442 ] {15bdaef2-60d2-464a-a419-91e5359cd055} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT L1Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 73, line 73) (in query: SELECT L1Normalize(NULL, NULL);) 2025.06.13 15:40:06.958967 [ 3894 ] {096b6c0b-b413-4f39-b6d3-1dc76f025092} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT DISTINCT toTypeName(obj) FROM t_json_16. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58222) (comment: 01825_type_json_16.sh) (query 1, line 1) (in query: SELECT DISTINCT toTypeName(obj) FROM t_json_16;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:40:07.029399 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT L1Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:07.043214 [ 3894 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT DISTINCT toTypeName(obj) FROM t_json_16. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:40:07.347912 [ 8442 ] {85096509-87bc-4442-9b26-27c32c0ec11d} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT L2Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 75, line 75) (in query: SELECT L2Norm(NULL, NULL);) 2025.06.13 15:40:07.376597 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT L2Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:07.483308 [ 8442 ] {2383fa96-b628-4f6e-8406-bd0e72aa001d} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT L2Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 76, line 76) (in query: SELECT L2Normalize(NULL, NULL);) 2025.06.13 15:40:07.502005 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT L2Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:07.609231 [ 4098 ] {f78d78b3-9c61-4c61-8c55-7e98f2874314} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT obj FROM t_json_16 ORDER BY obj.id ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58268) (comment: 01825_type_json_16.sh) (query 1, line 1) (in query: SELECT obj FROM t_json_16 ORDER BY obj.id FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:40:07.637656 [ 4098 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT obj FROM t_json_16 ORDER BY obj.id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:40:07.832333 [ 8442 ] {e75070bf-8b65-4b5e-b26b-01fc4fd513b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 78, line 78) (in query: SELECT L2SquaredNorm(NULL, NULL);) 2025.06.13 15:40:07.839184 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:08.094841 [ 6234 ] {3de5f61b-b794-4336-a7b5-dc3eaef3ac84} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT obj.key_0.key_1.key_2.key_3.key_4, obj.key_0.key_1.key_2.key_3.key_6, obj.key_0.key_1.key_2.key_3.key_7, obj.key_0.key_1.key_2.key_5.key_6, obj.key_0.key_1.key_2.key_5.key_7 FROM t_json_16 ORDER BY obj.id ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58294) (comment: 01825_type_json_16.sh) (query 1, line 1) (in query: SELECT obj.key_0.key_1.key_2.key_3.key_4, obj.key_0.key_1.key_2.key_3.key_6, obj.key_0.key_1.key_2.key_3.key_7, obj.key_0.key_1.key_2.key_5.key_6, obj.key_0.key_1.key_2.key_5.key_7 FROM t_json_16 ORDER BY obj.id), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:40:08.109575 [ 6234 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT obj.key_0.key_1.key_2.key_3.key_4, obj.key_0.key_1.key_2.key_3.key_6, obj.key_0.key_1.key_2.key_3.key_7, obj.key_0.key_1.key_2.key_5.key_6, obj.key_0.key_1.key_2.key_5.key_7 FROM t_json_16 ORDER BY obj.id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:40:08.232600 [ 8442 ] {62b32eb3-5172-4fa3-8bb2-9635257ec982} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT LinfNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 81, line 81) (in query: SELECT LinfNorm(NULL, NULL);) 2025.06.13 15:40:08.245364 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT LinfNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:08.356998 [ 8442 ] {d0dfe279-75b5-416d-90c5-be6898d63ead} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT LinfNormalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 82, line 82) (in query: SELECT LinfNormalize(NULL, NULL);) 2025.06.13 15:40:08.369059 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT LinfNormalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:08.445895 [ 8442 ] {0ecbccbf-d4e1-48fc-ac44-5c5339d7958f} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 83, line 83) (in query: SELECT LpDistance(NULL, NULL);) 2025.06.13 15:40:08.458656 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:08.745711 [ 5978 ] {22137c25-0f35-438d-9e29-d41f135c279d} executeQuery: Code: 60. DB::Exception: Table test_la5p8on0.t_json_16 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58320) (comment: 01825_type_json_16.sh) (query 1, line 1) (in query: DROP TABLE t_json_16;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:40:08.771048 [ 5978 ] {} TCPHandler: Code: 60. DB::Exception: Table test_la5p8on0.t_json_16 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:40:08.984039 [ 8442 ] {17f751c0-f2f8-4130-a84b-84f874d8c9c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 2, should be 1: In scope SELECT MACNumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 86, line 86) (in query: SELECT MACNumToString(NULL, NULL);) 2025.06.13 15:40:08.995288 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 2, should be 1: In scope SELECT MACNumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:09.150305 [ 8442 ] {7154111d-3ef3-4371-b51e-0e3e71f506be} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 2, should be 1: In scope SELECT MACStringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 87, line 87) (in query: SELECT MACStringToNum(NULL, NULL);) 2025.06.13 15:40:09.168089 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 2, should be 1: In scope SELECT MACStringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:09.296594 [ 8442 ] {9594a172-2437-4504-9600-e61d7d142846} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 2, should be 1: In scope SELECT MACStringToOUI(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 88, line 88) (in query: SELECT MACStringToOUI(NULL, NULL);) 2025.06.13 15:40:09.304111 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 2, should be 1: In scope SELECT MACStringToOUI(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:09.382012 [ 4098 ] {0900f697-2960-4f2e-8f1b-e6f78b2ed025} executeQuery: Code: 57. DB::Exception: Table test_3yibpjsb.tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58290) (comment: 01889_key_condition_function_chains.sql) (query 8, line 10) (in query: CREATE TABLE tab (`t` DateTime) ENGINE = MergeTree ORDER BY toStartOfDay(t + 1) SETTINGS index_granularity = 25931, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 19941091, compact_parts_max_granules_to_buffer = 38, compact_parts_merge_max_bytes_to_prefetch_part = 5067647, merge_max_block_size = 17297, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7020024801, index_granularity_bytes = 22328246, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 69, 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 = 19919, primary_key_compress_block_size = 78102, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:40:09.407760 [ 4098 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3yibpjsb.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:40:09.576239 [ 8442 ] {5d4bd0be-c6fe-4d2a-a693-462e7d00105e} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 2, should be 1: In scope SELECT MD4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 90, line 90) (in query: SELECT MD4(NULL, NULL);) 2025.06.13 15:40:09.591173 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 2, should be 1: In scope SELECT MD4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:09.705909 [ 8442 ] {fc34b99a-5858-416b-96d5-5ee243155281} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 2, should be 1: In scope SELECT MD5(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 91, line 91) (in query: SELECT MD5(NULL, NULL);) 2025.06.13 15:40:09.726222 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 2, should be 1: In scope SELECT MD5(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:09.813448 [ 3931 ] {80bf7705-3aa4-4a1d-a33c-cb34178bd2ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 2, should be 1: In scope SELECT parseReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1008, line 1009) (in query: SELECT parseReadableSize(NULL, NULL);) 2025.06.13 15:40:09.845380 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 2, should be 1: In scope SELECT parseReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:09.934039 [ 3931 ] {1b359582-f52b-474f-bff3-dffe6fc133dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1009, line 1010) (in query: SELECT parseReadableSizeOrNull(NULL, NULL);) 2025.06.13 15:40:09.968400 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:10.035022 [ 3931 ] {fb45879f-00b3-4692-84b4-373404e8037c} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1010, line 1011) (in query: SELECT parseReadableSizeOrZero(NULL, NULL);) 2025.06.13 15:40:10.044114 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:10.283996 [ 8442 ] {53d839c1-3ef4-4236-b2e8-40a9ac4423d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 95, line 95) (in query: SELECT OCTET_LENGTH(NULL, NULL);) 2025.06.13 15:40:10.294773 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:10.379546 [ 9636 ] {7830c5f4-7f60-4fa2-8fcb-084775d8c1ca} 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.20286.altinityantalya (altinity build)) (from [::1]:58386) (comment: 02246_is_secure_query_log.sh) (query 1, line 1) (in query: select interface, is_secure from system.query_log where query_id = '2246_test_15_client_secure' and type = 'QueryFinish' and current_database = currentDatabase()), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:40:10.504372 [ 9636 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:40:10.645037 [ 3931 ] {5b6e9b9f-7449-4a83-8323-d8ac9d7df10f} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 2, should be 1: In scope SELECT path(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1014, line 1015) (in query: SELECT path(NULL, NULL);) 2025.06.13 15:40:10.655919 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 2, should be 1: In scope SELECT path(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:10.827347 [ 3931 ] {5323dda7-c9b3-49f2-8b50-86fd6dd79925} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 2, should be 1: In scope SELECT pathFull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1015, line 1016) (in query: SELECT pathFull(NULL, NULL);) 2025.06.13 15:40:10.837767 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 2, should be 1: In scope SELECT pathFull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:10.958198 [ 8442 ] {0efeea79-0a0a-4400-9519-306fb08ebfd7} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT REGEXP_REPLACE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 99, line 99) (in query: SELECT REGEXP_REPLACE(NULL, NULL);) 2025.06.13 15:40:10.965835 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT REGEXP_REPLACE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:10.996084 [ 3931 ] {be3f32c2-b35e-4c46-b1f9-4d550b11e578} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1016, line 1017) (in query: SELECT percentRank(NULL, NULL);) 2025.06.13 15:40:11.008130 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:40:11.044622 [ 8442 ] {7f83ab22-2462-44b8-8413-99a04f612e20} executeQuery: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 2, should be 1: In scope SELECT RIPEMD160(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 100, line 100) (in query: SELECT RIPEMD160(NULL, NULL);) 2025.06.13 15:40:11.076171 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 2, should be 1: In scope SELECT RIPEMD160(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:11.196457 [ 8442 ] {056099f7-34e1-4576-9de3-3d63d72b44d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT SCHEMA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 101, line 101) (in query: SELECT SCHEMA(NULL, NULL);) 2025.06.13 15:40:11.218218 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT SCHEMA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:11.267315 [ 3931 ] {0aada853-f4d7-4dc1-b185-d03ffb142f20} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1017, line 1018) (in query: SELECT percent_rank(NULL, NULL);) 2025.06.13 15:40:11.271472 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:40:11.326169 [ 3931 ] {bf98954c-8705-47b3-87ea-6e6979c2af5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 2, should be 0: In scope SELECT pi(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1018, line 1019) (in query: SELECT pi(NULL, NULL);) 2025.06.13 15:40:11.338069 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 2, should be 0: In scope SELECT pi(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:11.437959 [ 8442 ] {22c1cd6b-467c-42f0-b7d9-9bc9d373084c} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 2, should be 1: In scope SELECT SHA1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 103, line 103) (in query: SELECT SHA1(NULL, NULL);) 2025.06.13 15:40:11.445961 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 2, should be 1: In scope SELECT SHA1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:11.561316 [ 8442 ] {5643049e-7694-48c4-a2c1-714e011336d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 2, should be 1: In scope SELECT SHA224(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 104, line 104) (in query: SELECT SHA224(NULL, NULL);) 2025.06.13 15:40:11.569330 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 2, should be 1: In scope SELECT SHA224(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:11.712640 [ 8442 ] {91f2ebb3-fd69-4670-8c1a-2f6339883980} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 2, should be 1: In scope SELECT SHA256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 105, line 105) (in query: SELECT SHA256(NULL, NULL);) 2025.06.13 15:40:11.735833 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 2, should be 1: In scope SELECT SHA256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:11.766273 [ 4107 ] {aa372954-4ae6-46f2-b6ef-21a1743ff5fa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=836). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58400) (comment: 00954_resample_combinator.sql) (query 9, line 9) (in query: select arrayReduce('groupArrayResample(1, 7, 1)', [10, 11, 12, 13, 14, 15, 16, 17, 18, 19], [0, 1, 2, 3, 4, 5, 6, 7, 8, 9]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:40:11.786618 [ 4107 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=873, jobs=836). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:40:11.880320 [ 8442 ] {e95ed50d-fda6-4486-9647-5349c2adbbc7} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 2, should be 1: In scope SELECT SHA384(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 106, line 106) (in query: SELECT SHA384(NULL, NULL);) 2025.06.13 15:40:11.899362 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 2, should be 1: In scope SELECT SHA384(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:12.085782 [ 8442 ] {7f35eb2d-8254-4fcb-bb4c-b7aa2cd7a071} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 2, should be 1: In scope SELECT SHA512(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 107, line 107) (in query: SELECT SHA512(NULL, NULL);) 2025.06.13 15:40:12.094852 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 2, should be 1: In scope SELECT SHA512(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:12.131661 [ 3931 ] {b46c4234-d31a-4434-8ca0-223dc64ac26e} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1023, line 1024) (in query: SELECT polygonAreaCartesian(NULL, NULL);) 2025.06.13 15:40:12.147130 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:12.173747 [ 8442 ] {bd143c2b-2932-4458-81ce-41d31a95d9ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 2, should be 1: In scope SELECT SHA512_256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 108, line 108) (in query: SELECT SHA512_256(NULL, NULL);) 2025.06.13 15:40:12.192560 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 2, should be 1: In scope SELECT SHA512_256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:12.236601 [ 3931 ] {01866b7a-00c1-4d87-bd13-ac73ff0fa475} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1024, line 1025) (in query: SELECT polygonAreaSpherical(NULL, NULL);) 2025.06.13 15:40:12.260938 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:12.362203 [ 3931 ] {9b72b06e-e822-4d0a-9b64-d9316023fb18} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1025, line 1026) (in query: SELECT polygonConvexHullCartesian(NULL, NULL);) 2025.06.13 15:40:12.374085 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:12.523060 [ 3931 ] {f4e789f1-5f85-4b81-948b-1564bfb613f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1026, line 1027) (in query: SELECT polygonPerimeterCartesian(NULL, NULL);) 2025.06.13 15:40:12.540771 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:12.635384 [ 3931 ] {e788aba9-9b68-408b-b3ab-f1cf0239197c} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1027, line 1028) (in query: SELECT polygonPerimeterSpherical(NULL, NULL);) 2025.06.13 15:40:12.647222 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:13.132644 [ 8442 ] {f8f051de-b9ec-47fd-9b96-5635c228f581} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT SUBSTRING_INDEX(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 112, line 112) (in query: SELECT SUBSTRING_INDEX(NULL, NULL);) 2025.06.13 15:40:13.192966 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT SUBSTRING_INDEX(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:13.697271 [ 8442 ] {96b7de50-53df-4ace-ad6c-3e47188f26df} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT TO_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 115, line 115) (in query: SELECT TO_BASE64(NULL, NULL);) 2025.06.13 15:40:13.722370 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT TO_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:14.363922 [ 8442 ] {cb0c820d-4634-4de7-bb4e-3334614895f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 120, line 120) (in query: SELECT URLHierarchy(NULL, NULL);) 2025.06.13 15:40:14.369052 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:14.500700 [ 8442 ] {4cd78375-3762-4a83-a7ab-b4f618939e42} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 121, line 121) (in query: SELECT URLPathHierarchy(NULL, NULL);) 2025.06.13 15:40:14.532381 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:14.620132 [ 8442 ] {e6c1c5b8-8e3a-44b2-8379-60802f048007} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTCTimestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 122, line 122) (in query: SELECT UTCTimestamp(NULL, NULL);) 2025.06.13 15:40:14.638440 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTCTimestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:14.819824 [ 8442 ] {ed56e2e8-2d4e-4c2f-b3ff-4eff14ef176e} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTC_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 123, line 123) (in query: SELECT UTC_timestamp(NULL, NULL);) 2025.06.13 15:40:14.828951 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTC_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:16.913995 [ 8442 ] {d15e3e1e-8b0c-4374-80d1-c6594cfeb230} executeQuery: Code: 43. DB::Exception: Second argument to _CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT _CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 135, line 135) (in query: SELECT _CAST(NULL, NULL);) 2025.06.13 15:40:16.925625 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to _CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT _CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:17.019945 [ 8442 ] {1b8975fe-3ced-48c8-8840-c9cd4c555a78} executeQuery: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly: In scope SELECT __actionName(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 136, line 136) (in query: SELECT __actionName(NULL, NULL);) 2025.06.13 15:40:17.030666 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly: In scope SELECT __actionName(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:40:17.161070 [ 3931 ] {6ce4f0a8-1bb2-4a62-8c80-1e2645e61da8} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 2, should be 6: In scope SELECT proportionsZTest(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1050, line 1051) (in query: SELECT proportionsZTest(NULL, NULL);) 2025.06.13 15:40:17.180564 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 2, should be 6: In scope SELECT proportionsZTest(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:17.305520 [ 3931 ] {f2296740-9995-433c-a21d-18dcd0bd60bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 2, should be 1: In scope SELECT protocol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1051, line 1052) (in query: SELECT protocol(NULL, NULL);) 2025.06.13 15:40:17.327905 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 2, should be 1: In scope SELECT protocol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:17.417674 [ 3931 ] {94221b4d-6e5c-4517-91af-56fc9447cdf2} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 2, should be 1: In scope SELECT punycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1052, line 1053) (in query: SELECT punycodeDecode(NULL, NULL);) 2025.06.13 15:40:17.434393 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 2, should be 1: In scope SELECT punycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:17.438851 [ 8442 ] {925493bb-9a89-4d9b-ace3-ec2cb9446526} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 2, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 139, line 139) (in query: SELECT __bitSwapLastTwo(NULL, NULL);) 2025.06.13 15:40:17.462479 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 2, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:17.579697 [ 3931 ] {59fb1f8a-ce4c-4831-80a2-6901d2a60041} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 2, should be 1: In scope SELECT punycodeEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1053, line 1054) (in query: SELECT punycodeEncode(NULL, NULL);) 2025.06.13 15:40:17.585462 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 2, should be 1: In scope SELECT punycodeEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:17.602550 [ 8442 ] {aab8626d-27c3-4ef2-ae69-174fb159303a} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 2, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 140, line 140) (in query: SELECT __bitWrapperFunc(NULL, NULL);) 2025.06.13 15:40:17.635570 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 2, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:17.855490 [ 8442 ] {76a1abf2-7d1a-4696-bfdc-95ead1071651} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 2, should be 1: In scope SELECT __getScalar(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 141, line 141) (in query: SELECT __getScalar(NULL, NULL);) 2025.06.13 15:40:17.860677 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 2, should be 1: In scope SELECT __getScalar(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:17.948418 [ 8442 ] {4d427db9-5289-455d-95af-ae241be359f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 2, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 142, line 142) (in query: SELECT __scalarSubqueryResult(NULL, NULL);) 2025.06.13 15:40:17.957328 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 2, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:18.123337 [ 8442 ] {0c9ca731-8070-4621-8186-93df8d1c6d45} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 2, should be 1: In scope SELECT abs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 143, line 143) (in query: SELECT abs(NULL, NULL);) 2025.06.13 15:40:18.144113 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 2, should be 1: In scope SELECT abs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:18.260415 [ 8442 ] {7400fac1-3e95-44a7-bc81-72589fc40883} executeQuery: Code: 43. DB::Exception: Second argument to accurateCast must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCast(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 144, line 144) (in query: SELECT accurateCast(NULL, NULL);) 2025.06.13 15:40:18.273514 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCast must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCast(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:18.359950 [ 8442 ] {78ed4de5-9970-4138-9e51-f00b7ac2643e} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 145, line 145) (in query: SELECT accurateCastOrDefault(NULL, NULL);) 2025.06.13 15:40:18.367183 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:18.451516 [ 8442 ] {7d1bbd98-3a8a-47d0-ae64-d9a5210598e0} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrNull must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCastOrNull(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 146, line 146) (in query: SELECT accurateCastOrNull(NULL, NULL);) 2025.06.13 15:40:18.471718 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrNull must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCastOrNull(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:18.585448 [ 8442 ] {381b5572-f3fe-4ed5-9a83-7fdfa5f86458} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 2, should be 1: In scope SELECT acos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 147, line 147) (in query: SELECT acos(NULL, NULL);) 2025.06.13 15:40:18.595232 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 2, should be 1: In scope SELECT acos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:18.794300 [ 8442 ] {e1f9c7a9-b962-4f66-a5c7-42105ab17245} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 2, should be 1: In scope SELECT acosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 148, line 148) (in query: SELECT acosh(NULL, NULL);) 2025.06.13 15:40:18.813065 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 2, should be 1: In scope SELECT acosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:19.939808 [ 4098 ] {c03bf5e0-1b4f-4e4a-a965-5c0f0e6a2f5c} 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.20286.altinityantalya (altinity build)) (from [::1]:39578) (comment: 00976_max_execution_speed.sql) (query 2, line 2) (in query: SELECT count() FROM system.numbers;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:40:19.960099 [ 4098 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:40:20.126005 [ 6234 ] {5abb397f-abaa-41bb-861b-86f001eb6e5d} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_zcudb9ph.quorum1 (7304807e-82d5-4c68-839d-2e5bd989e502)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39508) (comment: 00732_quorum_insert_simple_test_2_parts_zookeeper_long.sql) (query 8, line 16) (in query: INSERT INTO quorum1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:40:20.142255 [ 8099 ] {9d6bf21d-9c2c-45aa-8121-ec3125f3760a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37714) (comment: 00562_rewrite_select_expression_with_union.sql) (in query: DROP DATABASE IF EXISTS test_qtih1foz SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:40:20.152879 [ 6234 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_zcudb9ph.quorum1 (7304807e-82d5-4c68-839d-2e5bd989e502)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:40:20.160302 [ 8099 ] {9d6bf21d-9c2c-45aa-8121-ec3125f3760a} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:20.338583 [ 6234 ] {59b2f130-bc45-4146-aca3-8832f379498f} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_zcudb9ph.quorum1 (7304807e-82d5-4c68-839d-2e5bd989e502)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37736) (comment: 00732_quorum_insert_simple_test_2_parts_zookeeper_long.sql) (in query: DROP DATABASE IF EXISTS test_zcudb9ph SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:40:20.341987 [ 6234 ] {59b2f130-bc45-4146-aca3-8832f379498f} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_zcudb9ph.quorum1 (7304807e-82d5-4c68-839d-2e5bd989e502)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:21.639100 [ 8442 ] {80157051-2042-47bc-98e5-61f00746a9e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 2, should be 1: In scope SELECT addressToLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 163, line 163) (in query: SELECT addressToLine(NULL, NULL);) 2025.06.13 15:40:21.652076 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 2, should be 1: In scope SELECT addressToLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:21.672377 [ 3931 ] {44348f5d-8550-4730-b9c5-57e55381a317} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1072, line 1073) (in query: SELECT quantiles(NULL, NULL);) 2025.06.13 15:40:21.692234 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:21.801073 [ 3931 ] {f41bbdda-f1a5-4a25-aa4c-7aa1dd1b7656} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1073, line 1074) (in query: SELECT quantilesBFloat16(NULL, NULL);) 2025.06.13 15:40:21.812547 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:21.818756 [ 8442 ] {67e7110e-bf91-4158-9c88-fe0e70eedc52} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 2, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 164, line 164) (in query: SELECT addressToLineWithInlines(NULL, NULL);) 2025.06.13 15:40:21.826532 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 2, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:22.010469 [ 8442 ] {028109d9-1a28-4798-8d5e-7f9a3fc89ae0} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 2, should be 1: In scope SELECT addressToSymbol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 165, line 165) (in query: SELECT addressToSymbol(NULL, NULL);) 2025.06.13 15:40:22.019305 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 2, should be 1: In scope SELECT addressToSymbol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:22.135260 [ 3931 ] {db22a30c-dd1e-4105-a6df-60e3288df46c} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1075, line 1076) (in query: SELECT quantilesDD(NULL, NULL);) 2025.06.13 15:40:22.166225 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:22.455271 [ 3931 ] {accd1063-a218-4c03-b841-126047d5d790} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1076, line 1077) (in query: SELECT quantilesDeterministic(NULL, NULL);) 2025.06.13 15:40:22.467975 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:22.563783 [ 3931 ] {239d678d-1b15-410d-96ef-bbbcbfba8f30} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1077, line 1078) (in query: SELECT quantilesExact(NULL, NULL);) 2025.06.13 15:40:22.573513 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:22.733375 [ 3931 ] {5d30616e-bce6-48d7-bee5-dd09b4b45a96} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1078, line 1079) (in query: SELECT quantilesExactExclusive(NULL, NULL);) 2025.06.13 15:40:22.748981 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:22.871200 [ 3931 ] {4b3980fa-9fc5-4f41-a61c-e056ec577c34} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1079, line 1080) (in query: SELECT quantilesExactHigh(NULL, NULL);) 2025.06.13 15:40:22.875236 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:22.936549 [ 3931 ] {84e014bc-9669-45a9-9559-fa25fda9c5bf} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1080, line 1081) (in query: SELECT quantilesExactInclusive(NULL, NULL);) 2025.06.13 15:40:22.945165 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:23.108105 [ 3931 ] {5e5de10f-31f0-46cd-8698-2c860cbd7dac} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1081, line 1082) (in query: SELECT quantilesExactLow(NULL, NULL);) 2025.06.13 15:40:23.125573 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:23.233362 [ 3931 ] {1cb6d3c3-a44e-49fb-a1ff-ecb43c223f38} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1082, line 1083) (in query: SELECT quantilesExactWeighted(NULL, NULL);) 2025.06.13 15:40:23.245100 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:23.324118 [ 3931 ] {1bc67250-3c19-4101-9ada-16ccde7cff2f} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1083, line 1084) (in query: SELECT quantilesExactWeightedInterpolated(NULL, NULL);) 2025.06.13 15:40:23.344010 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:23.452577 [ 3931 ] {ae4ac432-d6a3-4c88-b5a7-c1ee37eeabad} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1084, line 1085) (in query: SELECT quantilesGK(NULL, NULL);) 2025.06.13 15:40:23.473021 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:23.558028 [ 3931 ] {ae5cb47e-dda3-416d-aaa9-85c80d99eda5} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1085, line 1086) (in query: SELECT quantilesInterpolatedWeighted(NULL, NULL);) 2025.06.13 15:40:23.574091 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:23.692388 [ 3931 ] {2bd31d07-ad13-4956-96d6-e024deaa3586} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1086, line 1087) (in query: SELECT quantilesTDigest(NULL, NULL);) 2025.06.13 15:40:23.701571 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:23.874634 [ 3931 ] {6e263ca7-01b7-4306-bdd6-3ddba7c300ed} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1087, line 1088) (in query: SELECT quantilesTDigestWeighted(NULL, NULL);) 2025.06.13 15:40:23.882589 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:24.015055 [ 3931 ] {37c1010b-5ccd-4ee1-b028-ea2e863b5255} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1088, line 1089) (in query: SELECT quantilesTiming(NULL, NULL);) 2025.06.13 15:40:24.023930 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:24.037594 [ 8431 ] {618d4b90-9d26-4c94-a64a-8a5c686af80d} executeQuery: Code: 36. DB::Exception: Cannot load time zone /abc: In scope SELECT toDateTime(0, '/abc'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57532) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 1, line 1) (in query: select toDateTime(0, '/abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c8502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c3635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c4015e8 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c400f59 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3b379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3b180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b055ea5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b055947 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:40:24.047103 [ 8431 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone /abc: In scope SELECT toDateTime(0, '/abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c8502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c3635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c4015e8 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c400f59 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3b379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3b180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b055ea5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b055947 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:40:24.219166 [ 3931 ] {1e96a363-8eef-4b05-a9c6-b8543788f996} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1089, line 1090) (in query: SELECT quantilesTimingWeighted(NULL, NULL);) 2025.06.13 15:40:24.244164 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:24.305302 [ 8431 ] {c815dd36-2d60-4fd1-952d-775444ee1cf1} executeQuery: Code: 36. DB::Exception: Cannot load time zone ./abc: In scope SELECT toDateTime(0, './abc'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57532) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 2, line 2) (in query: select toDateTime(0, './abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c8502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c3635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c4015e8 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c400f59 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3b379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3b180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b055ea5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b055947 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:40:24.354792 [ 3931 ] {92e62a9c-3e45-4e6b-b2ad-297e884e7d44} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT queryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1090, line 1091) (in query: SELECT queryID(NULL, NULL);) 2025.06.13 15:40:24.357523 [ 8431 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone ./abc: In scope SELECT toDateTime(0, './abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c8502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c3635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c4015e8 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c400f59 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3b379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3b180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b055ea5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b055947 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:40:24.368106 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT queryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:24.545955 [ 8442 ] {931ce201-2a5a-4e55-9827-61476d1ea8f4} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 177, line 177) (in query: SELECT anyLastRespectNulls(NULL, NULL);) 2025.06.13 15:40:24.548437 [ 8431 ] {bbd7f23c-af87-458b-87c8-ec6aa2abcf0f} executeQuery: Code: 36. DB::Exception: Cannot load time zone ../abc: In scope SELECT toDateTime(0, '../abc'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57532) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 3, line 3) (in query: select toDateTime(0, '../abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c8502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c3635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c4015e8 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c400f59 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3b379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3b180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b055ea5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b055947 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:40:24.552176 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:24.555321 [ 8431 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone ../abc: In scope SELECT toDateTime(0, '../abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c8502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c3635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c4015e8 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c400f59 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3b379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3b180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b055ea5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b055947 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:40:24.577122 [ 3931 ] {2201e0a7-f1c9-4a95-a613-be8c3d035533} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 2, should be 1: In scope SELECT queryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1091, line 1092) (in query: SELECT queryString(NULL, NULL);) 2025.06.13 15:40:24.587959 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 2, should be 1: In scope SELECT queryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:24.737370 [ 8431 ] {2b9fa612-f8dc-4f83-8913-5f137bdc485b} executeQuery: Code: 36. DB::Exception: Cannot load time zone ~/abc: In scope SELECT toDateTime(0, '~/abc'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57532) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 4, line 4) (in query: select toDateTime(0, '~/abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c8502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c3635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c4015e8 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c400f59 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3b379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3b180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b055ea5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b055947 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:40:24.743625 [ 8442 ] {41c9337f-72e8-4754-9ac9-2eb0d1b6b90f} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 178, line 178) (in query: SELECT anyLast_respect_nulls(NULL, NULL);) 2025.06.13 15:40:24.750815 [ 8431 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone ~/abc: In scope SELECT toDateTime(0, '~/abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c8502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c3635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c4015e8 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c400f59 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3b379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3b180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b055ea5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b055947 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:40:24.753048 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:24.765033 [ 3931 ] {16e2e535-87e0-4d06-bc23-bd1cb73de8b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1092, line 1093) (in query: SELECT queryStringAndFragment(NULL, NULL);) 2025.06.13 15:40:24.793043 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:24.839044 [ 8442 ] {ddd2fb13-07ef-4bb8-84ab-10699dfd15b4} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 179, line 179) (in query: SELECT anyRespectNulls(NULL, NULL);) 2025.06.13 15:40:24.847417 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:24.855754 [ 8431 ] {d1d89ee9-c0a2-4000-9acf-5fee31afee11} executeQuery: Code: 36. DB::Exception: Cannot load time zone abc/../../cba: In scope SELECT toDateTime(0, 'abc/../../cba'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57532) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 5, line 5) (in query: select toDateTime(0, 'abc/../../cba');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c8502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c3635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c4015e8 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c400f59 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3b379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3b180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b055ea5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b055947 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:40:24.890920 [ 8431 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone abc/../../cba: In scope SELECT toDateTime(0, 'abc/../../cba'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x00000000239c8502 6. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x00000000239c3635 7. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002c4015e8 8. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002c400f59 9. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String&&) @ 0x0000000018d3b379 10. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x0000000018d3b180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b055ea5 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b055947 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:40:25.002643 [ 8442 ] {a8fbbd32-431c-4fad-a01a-40f55608045c} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 180, line 180) (in query: SELECT anyValueRespectNulls(NULL, NULL);) 2025.06.13 15:40:25.010133 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:25.064104 [ 3931 ] {7bc37dfe-da86-41ae-8505-06b7ff5fdb20} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1093, line 1094) (in query: SELECT query_id(NULL, NULL);) 2025.06.13 15:40:25.071885 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:25.115608 [ 8442 ] {d92887dc-b090-437c-a2f8-1ecbb4e21484} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 181, line 181) (in query: SELECT any_respect_nulls(NULL, NULL);) 2025.06.13 15:40:25.131548 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:25.142725 [ 3931 ] {91f1cf70-887f-47ca-b99b-c21bc286a472} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 2, should be 1: In scope SELECT radians(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1094, line 1095) (in query: SELECT radians(NULL, NULL);) 2025.06.13 15:40:25.153857 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 2, should be 1: In scope SELECT radians(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:25.245028 [ 3931 ] {a860c2f9-6dbd-44e6-8ab7-e46713ed6998} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1095, line 1096) (in query: SELECT rand(NULL, NULL);) 2025.06.13 15:40:25.263807 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:25.465270 [ 3931 ] {365e179a-ffc5-4781-82de-74c128dfbf6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1096, line 1097) (in query: SELECT rand32(NULL, NULL);) 2025.06.13 15:40:25.485432 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:25.551909 [ 8442 ] {7b4d9927-794a-423b-b244-affaf0a0f45e} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 183, line 183) (in query: SELECT any_value_respect_nulls(NULL, NULL);) 2025.06.13 15:40:25.563032 [ 3931 ] {2fce9d41-b088-461e-b98b-3de2606065e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1097, line 1098) (in query: SELECT rand64(NULL, NULL);) 2025.06.13 15:40:25.569904 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:25.575228 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:26.249198 [ 3931 ] {fe979a15-c737-433b-9a37-9975c00959a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 2, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1100, line 1101) (in query: SELECT randCanonical(NULL, NULL);) 2025.06.13 15:40:26.261321 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 2, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:26.461054 [ 3931 ] {496ea70d-5cea-4b4c-9b29-72c5dbf3171a} executeQuery: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 2, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1102, line 1103) (in query: SELECT randConstant(NULL, NULL);) 2025.06.13 15:40:26.485210 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 2, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:26.774857 [ 9642 ] {a6c2c374-f373-4663-a834-77109233eb26} executeQuery: Code: 53. DB::Exception: Cannot convert string 'numbers1' to type UInt64. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57604) (comment: 00578_merge_table_shadow_virtual_column.sql) (query 5, line 7) (in query: SELECT count() FROM merge(currentDatabase(), '^numbers\\d+$') WHERE _table='numbers1';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:40:26.783550 [ 9642 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'numbers1' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:40:27.784174 [ 5112 ] {f6b089e4-b8fc-48eb-b228-cfe01699c87c} executeQuery: Code: 69. DB::Exception: Too large parameter(s) for aggregate function 'topKWeighted' (maximum is 16777215). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57698) (comment: 01471_top_k_range_check.sql) (query 1, line 1) (in query: SELECT length(topKWeighted(2, -9223372036854775808)(number, 1025)) FROM system.numbers;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:506: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionTopK(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000278c17aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:40:27.804720 [ 5112 ] {} TCPHandler: Code: 69. DB::Exception: Too large parameter(s) for aggregate function 'topKWeighted' (maximum is 16777215). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:506: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionTopK(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000278c17aa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:40:28.137209 [ 3931 ] {08ef0bf0-6d70-4d06-86af-5c326b161eaf} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 2, should be 1: In scope SELECT randomFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1111, line 1112) (in query: SELECT randomFixedString(NULL, NULL);) 2025.06.13 15:40:28.152803 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 2, should be 1: In scope SELECT randomFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:28.654871 [ 3931 ] {82973769-1fe5-4ed5-8a5f-51d7b189793b} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 2, should be 1: In scope SELECT randomStringUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1114, line 1115) (in query: SELECT randomStringUTF8(NULL, NULL);) 2025.06.13 15:40:28.675170 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 2, should be 1: In scope SELECT randomStringUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:28.931647 [ 9642 ] {e1f53a99-2b88-47d0-8034-f283f7ae546d} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57730) (comment: 02516_projections_and_context.sql) (query 4, line 4) (in query: set enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:28.951356 [ 9642 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:29.174498 [ 3931 ] {bfcbc441-3664-4614-962f-0e111bdddf2c} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1116, line 1117) (in query: SELECT rank(NULL, NULL);) 2025.06.13 15:40:29.199904 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:40:29.211998 [ 8442 ] {53bafb7d-c9f5-4a18-8d2c-374613327972} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 2, should be 1: In scope SELECT arrayDistinct(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 201, line 201) (in query: SELECT arrayDistinct(NULL, NULL);) 2025.06.13 15:40:29.231351 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 2, should be 1: In scope SELECT arrayDistinct(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:29.630614 [ 3931 ] {f2be7573-54cc-4992-bc9c-b4df8d05fee6} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1118, line 1119) (in query: SELECT readWKTLineString(NULL, NULL);) 2025.06.13 15:40:29.647367 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:29.757155 [ 3931 ] {640c91e6-14c5-465f-8e34-5a543a13e0d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1119, line 1120) (in query: SELECT readWKTMultiLineString(NULL, NULL);) 2025.06.13 15:40:29.768336 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:29.795577 [ 5112 ] {f671204b-f0c9-46d8-b167-4893a1f1b763} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57772) (comment: 03101_analyzer_identifiers_4.sql) (query 2, line 4) (in query: DROP DATABASE IF EXISTS test_1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:29.816224 [ 5112 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:29.889348 [ 3931 ] {e06e4d02-4a73-48e0-b9c4-db577f427533} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1120, line 1121) (in query: SELECT readWKTMultiPolygon(NULL, NULL);) 2025.06.13 15:40:29.899093 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:29.983095 [ 3931 ] {1eef8e00-cb35-458b-8263-893a63612ba9} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 2, should be 1: In scope SELECT readWKTPoint(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1121, line 1122) (in query: SELECT readWKTPoint(NULL, NULL);) 2025.06.13 15:40:29.997704 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 2, should be 1: In scope SELECT readWKTPoint(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:30.009192 [ 8442 ] {37a050c0-b780-4a33-96bc-81c9864dc9f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 2, should be 1: In scope SELECT arrayEnumerate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 205, line 205) (in query: SELECT arrayEnumerate(NULL, NULL);) 2025.06.13 15:40:30.023088 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 2, should be 1: In scope SELECT arrayEnumerate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:30.084634 [ 3931 ] {759bddb3-9170-4b78-8280-692458704ffb} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1122, line 1123) (in query: SELECT readWKTPolygon(NULL, NULL);) 2025.06.13 15:40:30.101400 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:30.197070 [ 3931 ] {55d7897a-8184-45cf-8643-7086ba22ae32} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 2, should be 1: In scope SELECT readWKTRing(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1123, line 1124) (in query: SELECT readWKTRing(NULL, NULL);) 2025.06.13 15:40:30.233766 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 2, should be 1: In scope SELECT readWKTRing(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:30.551613 [ 3931 ] {175ab8fc-b976-4ad3-aaf3-b366414b1a9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 2, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1125, line 1126) (in query: SELECT regexpQuoteMeta(NULL, NULL);) 2025.06.13 15:40:30.569942 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 2, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:30.687948 [ 8430 ] {9f9c8479-2cd9-41e6-a2bd-691ceae59f63} 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.20286.altinityantalya (altinity build)) (from [::1]:57792) (comment: 02706_array_map_tuples.sql) (query 4, line 5) (in query: WITH [(1, 2)] AS arr1 SELECT arrayMap((x, y, z) -> (y, x, z), arr1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdbf6f 5. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000020f19f4f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2d604 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:40:30.701962 [ 8430 ] {} TCPHandler: Code: 43. DB::Exception: First argument for this overload of arrayMap must be a function with 1 arguments, found Function((?, ?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdbf6f 5. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000020f19f4f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2d604 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:40:30.896365 [ 8430 ] {b9ffa5af-aedb-4ce4-a7f0-78e22eac5a88} 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.20286.altinityantalya (altinity build)) (from [::1]:57792) (comment: 02706_array_map_tuples.sql) (query 5, line 6) (in query: WITH [1, 2] AS arr1 SELECT arrayMap((x, y) -> (y, x), arr1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdbf6f 5. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000020f19f4f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2d604 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:40:30.911746 [ 8430 ] {} TCPHandler: Code: 43. DB::Exception: First argument for this overload of arrayMap must be a function with 1 arguments, found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000017cdbf6f 5. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000020f19f4f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3389: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2d604 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:40:31.725354 [ 6193 ] {efcdd97b-bd8a-45e3-ba52-6a28e5098b67} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57564) (comment: 03036_reading_s3_archives.sql) (query 10, line 13) (in query: select id, data, _size, _file, _path from s3(s3_conn, filename='03036_archive2.zip :: nonexistent.csv');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000001a05868f 5. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:197: DB::ReadBufferIterator::next() @ 0x000000002b536150 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317bbcfc 7. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1a90 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:537: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x000000002b526e9f 9. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:64: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, std::shared_ptr, std::shared_ptr, std::optional, String&, std::shared_ptr const&) @ 0x000000002b614b3a 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:137: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool, bool, std::optional) @ 0x000000002b51f55b 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x000000002859629a 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595de7 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595bdb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285458bd 15. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:125: DB::TableFunctionObjectStorageClusterFallback>::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285de109 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 17. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:40:31.751586 [ 6193 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000001a05868f 5. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:197: DB::ReadBufferIterator::next() @ 0x000000002b536150 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317bbcfc 7. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1a90 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:537: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x000000002b526e9f 9. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:64: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, std::shared_ptr, std::shared_ptr, std::optional, String&, std::shared_ptr const&) @ 0x000000002b614b3a 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:137: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool, bool, std::optional) @ 0x000000002b51f55b 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x000000002859629a 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595de7 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595bdb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285458bd 15. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:125: DB::TableFunctionObjectStorageClusterFallback>::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285de109 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 17. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:40:32.153301 [ 8442 ] {5ca4918d-f169-4bf7-9f9b-9bea0299c480} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT arrayFlatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 216, line 216) (in query: SELECT arrayFlatten(NULL, NULL);) 2025.06.13 15:40:32.178638 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT arrayFlatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:32.208516 [ 6193 ] {8e0ed94a-0f3c-4801-9a13-5d5aef3c35ce} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57564) (comment: 03036_reading_s3_archives.sql) (query 11, line 14) (in query: select id, data, _size, _file, _path from s3(s3_conn, filename='03036_archive2.zip :: nonexistent{2..3}.csv');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000001a05868f 5. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:197: DB::ReadBufferIterator::next() @ 0x000000002b536150 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317bbcfc 7. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1a90 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:537: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x000000002b526e9f 9. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:64: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, std::shared_ptr, std::shared_ptr, std::optional, String&, std::shared_ptr const&) @ 0x000000002b614b3a 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:137: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool, bool, std::optional) @ 0x000000002b51f55b 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x000000002859629a 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595de7 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595bdb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285458bd 15. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:125: DB::TableFunctionObjectStorageClusterFallback>::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285de109 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 17. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:40:32.215743 [ 6193 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000001a05868f 5. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:197: DB::ReadBufferIterator::next() @ 0x000000002b536150 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317bbcfc 7. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1a90 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:537: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x000000002b526e9f 9. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:64: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, std::shared_ptr, std::shared_ptr, std::optional, String&, std::shared_ptr const&) @ 0x000000002b614b3a 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:137: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool, bool, std::optional) @ 0x000000002b51f55b 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x000000002859629a 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595de7 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, bool, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&, bool&&) @ 0x0000000028595bdb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285458bd 15. ./build_docker/./src/TableFunctions/TableFunctionObjectStorageClusterFallback.cpp:125: DB::TableFunctionObjectStorageClusterFallback>::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000285de109 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 17. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:40:32.276344 [ 8442 ] {3460b50c-b7fe-46de-8ef1-2f8fb9528dbc} executeQuery: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(NULL, NULL). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 217, line 217) (in query: SELECT arrayFold(NULL, NULL);) 2025.06.13 15:40:32.287614 [ 8442 ] {} TCPHandler: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(NULL, NULL). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:40:32.724461 [ 8442 ] {71c16ae6-dd54-4537-ac46-1696e513a64e} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 2, should be 1: In scope SELECT arrayJoin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 220, line 220) (in query: SELECT arrayJoin(NULL, NULL);) 2025.06.13 15:40:32.734524 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 2, should be 1: In scope SELECT arrayJoin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:32.840235 [ 3931 ] {f6a57384-91c4-49df-9660-a1e527b78665} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1137, line 1138) (in query: SELECT reinterpretAsDate(NULL, NULL);) 2025.06.13 15:40:32.847263 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:32.926811 [ 8432 ] {6a10a26b-e435-408f-abf4-3205b293f701} executeQuery: Code: 475. DB::Exception: Sort FILL TO expression must be constant with numeric type. Actual '2024-02-17'. In scope SELECT * FROM users ORDER BY date ASC WITH FILL TO '2024-02-17' STEP toIntervalHour(1). (INVALID_WITH_FILL_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57858) (comment: 03248_with_fill_string_crash.sql) (query 3, line 7) (in query: SELECT * FROM users ORDER BY date WITH FILL TO '2024-02-17' STEP toIntervalHour(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4070: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4740b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfa0ac 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:40:32.935475 [ 8432 ] {} TCPHandler: Code: 475. DB::Exception: Sort FILL TO expression must be constant with numeric type. Actual '2024-02-17'. In scope SELECT * FROM users ORDER BY date ASC WITH FILL TO '2024-02-17' STEP toIntervalHour(1). (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4070: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4740b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5641: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfa0ac 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:40:32.956620 [ 3931 ] {086d6189-f135-41cd-a9b1-c6c129be06aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1138, line 1139) (in query: SELECT reinterpretAsDateTime(NULL, NULL);) 2025.06.13 15:40:32.963504 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:33.029512 [ 3931 ] {f1573f1d-d5cf-4e7e-aabb-2585449651e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1139, line 1140) (in query: SELECT reinterpretAsFixedString(NULL, NULL);) 2025.06.13 15:40:33.062894 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:33.141542 [ 3931 ] {ce383897-7142-4d85-aae8-d277d67c8dfc} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1140, line 1141) (in query: SELECT reinterpretAsFloat32(NULL, NULL);) 2025.06.13 15:40:33.219570 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:33.276862 [ 3931 ] {ca11c665-fdf4-47e8-9162-56dec89e5fc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1141, line 1142) (in query: SELECT reinterpretAsFloat64(NULL, NULL);) 2025.06.13 15:40:33.286773 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:33.387608 [ 3931 ] {ba164988-5967-4bfa-b881-9aca5acdd36c} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1142, line 1143) (in query: SELECT reinterpretAsInt128(NULL, NULL);) 2025.06.13 15:40:33.402527 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:33.451986 [ 3931 ] {ce52a51c-d37e-4025-871e-7ae2203a5491} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1143, line 1144) (in query: SELECT reinterpretAsInt16(NULL, NULL);) 2025.06.13 15:40:33.470862 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:33.569095 [ 3931 ] {0a261fc3-554b-448d-a7f5-fc848bc622e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1144, line 1145) (in query: SELECT reinterpretAsInt256(NULL, NULL);) 2025.06.13 15:40:33.587319 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:33.737112 [ 3931 ] {2662ab5a-f1f8-4ee0-8548-73b44518a74d} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1145, line 1146) (in query: SELECT reinterpretAsInt32(NULL, NULL);) 2025.06.13 15:40:33.812289 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:33.874492 [ 3931 ] {cc7a5e7b-c656-4694-a3f3-fb09e971c31a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1146, line 1147) (in query: SELECT reinterpretAsInt64(NULL, NULL);) 2025.06.13 15:40:33.883368 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:34.063168 [ 3931 ] {375699c2-191d-40f6-a54e-0a426139bac0} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1147, line 1148) (in query: SELECT reinterpretAsInt8(NULL, NULL);) 2025.06.13 15:40:34.077188 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:34.199190 [ 3931 ] {b9777822-0410-4953-941c-019bc2196307} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1148, line 1149) (in query: SELECT reinterpretAsString(NULL, NULL);) 2025.06.13 15:40:34.206425 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:34.352132 [ 3931 ] {6aae80f3-a864-4aa3-b10a-33911ab59f53} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1149, line 1150) (in query: SELECT reinterpretAsUInt128(NULL, NULL);) 2025.06.13 15:40:34.376577 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:34.496407 [ 3931 ] {aaa6f18e-9222-4f2a-8878-ea380f3c5bb5} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1150, line 1151) (in query: SELECT reinterpretAsUInt16(NULL, NULL);) 2025.06.13 15:40:34.508277 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:34.612700 [ 3931 ] {fd0c1117-58f0-417f-82af-57eb72cb095a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1151, line 1152) (in query: SELECT reinterpretAsUInt256(NULL, NULL);) 2025.06.13 15:40:34.632034 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:34.774002 [ 3931 ] {cb8322f2-6cea-4ba7-85cc-4ac4736297bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1152, line 1153) (in query: SELECT reinterpretAsUInt32(NULL, NULL);) 2025.06.13 15:40:34.796010 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:34.879424 [ 8442 ] {11a55dcd-9843-452a-92c4-bd54ef2dcfe1} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 2, should be 1: In scope SELECT arrayPopBack(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 232, line 232) (in query: SELECT arrayPopBack(NULL, NULL);) 2025.06.13 15:40:34.880190 [ 3931 ] {77bae754-d861-4a6e-bfd4-b234f5b1f29b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1153, line 1154) (in query: SELECT reinterpretAsUInt64(NULL, NULL);) 2025.06.13 15:40:34.889121 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 2, should be 1: In scope SELECT arrayPopBack(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:34.894508 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:34.962061 [ 8442 ] {d4e37ae3-ab37-4391-8873-f1874bfc281a} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 2, should be 1: In scope SELECT arrayPopFront(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 233, line 233) (in query: SELECT arrayPopFront(NULL, NULL);) 2025.06.13 15:40:34.975119 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 2, should be 1: In scope SELECT arrayPopFront(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:34.975426 [ 6193 ] {0ce8ca2d-1ec0-47e1-8fa8-1ec7b53bbff3} executeQuery: Code: 56. DB::Exception: Unknown table engine s3. (UNKNOWN_STORAGE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57564) (comment: 03036_reading_s3_archives.sql) (query 18, line 21) (in query: CREATE table table_noexist Engine s3(s3_conn, filename='03036_archive2.zip :: nonexistent.csv');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageFactory.cpp:276: DB::StorageFactory::getStorageFeatures(String const&) const @ 0x00000000303cc792 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:990: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc63252 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:34.993528 [ 6193 ] {} TCPHandler: Code: 56. DB::Exception: Unknown table engine s3. (UNKNOWN_STORAGE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageFactory.cpp:276: DB::StorageFactory::getStorageFeatures(String const&) const @ 0x00000000303cc792 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:990: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc63252 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:34.997786 [ 3931 ] {d778fc5c-f494-442e-a2f6-9f3d8636b0c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1154, line 1155) (in query: SELECT reinterpretAsUInt8(NULL, NULL);) 2025.06.13 15:40:35.009994 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:35.019640 [ 2868 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5516 similar messages) 2025.06.13 15:40:35.087928 [ 3931 ] {cfedcea5-914e-407b-a04e-a5c399b3934c} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1155, line 1156) (in query: SELECT reinterpretAsUUID(NULL, NULL);) 2025.06.13 15:40:35.093405 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:35.322432 [ 3931 ] {b89e858a-8280-46e9-9b87-eb3c8a05d0ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1157, line 1158) (in query: SELECT replace(NULL, NULL);) 2025.06.13 15:40:35.342334 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:35.436668 [ 3931 ] {72b3967c-eca0-4cc6-92e5-a19c0fd2e0e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replaceAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1158, line 1159) (in query: SELECT replaceAll(NULL, NULL);) 2025.06.13 15:40:35.458871 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replaceAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:35.571624 [ 3931 ] {7469e3fc-33f5-44d7-801e-7a58a0dc26f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 2, should be 3: In scope SELECT replaceOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1159, line 1160) (in query: SELECT replaceOne(NULL, NULL);) 2025.06.13 15:40:35.575086 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 2, should be 3: In scope SELECT replaceOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:35.640784 [ 3931 ] {3d1a6d52-265b-4e4f-b23b-f7e38e42fc86} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1160, line 1161) (in query: SELECT replaceRegexpAll(NULL, NULL);) 2025.06.13 15:40:35.649637 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:35.694536 [ 8442 ] {dd11b189-8722-4b78-86d2-d2e13b86c58f} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 239, line 239) (in query: SELECT arrayReduce(NULL, NULL);) 2025.06.13 15:40:35.705084 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:35.726890 [ 3931 ] {261a5e27-ed5c-4954-9173-44bb67ed3107} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1161, line 1162) (in query: SELECT replaceRegexpOne(NULL, NULL);) 2025.06.13 15:40:35.741757 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:35.845088 [ 3931 ] {1d173b5a-7f01-47d7-9a15-7985c6eb5098} executeQuery: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1162, line 1163) (in query: SELECT replicate(NULL, NULL);) 2025.06.13 15:40:35.850774 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:36.078295 [ 8442 ] {e93b172f-4597-413d-9a3f-268fd21e0b60} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array' to function 'arrayResize'. Expected: Array, got: Nullable(Nothing): In scope SELECT arrayResize(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 241, line 241) (in query: SELECT arrayResize(NULL, NULL);) 2025.06.13 15:40:36.099177 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array' to function 'arrayResize'. Expected: Array, got: Nullable(Nothing): In scope SELECT arrayResize(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:36.145101 [ 3931 ] {3e99e192-1dac-4266-b508-827efa675467} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 2, should be 1: In scope SELECT reverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1164, line 1165) (in query: SELECT reverse(NULL, NULL);) 2025.06.13 15:40:36.164892 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 2, should be 1: In scope SELECT reverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:36.213307 [ 8442 ] {94e6363f-51e5-4ae2-9dd3-efe60dec8cdf} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 2, should be 1: In scope SELECT arrayReverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 242, line 242) (in query: SELECT arrayReverse(NULL, NULL);) 2025.06.13 15:40:36.228195 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 2, should be 1: In scope SELECT arrayReverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:36.253793 [ 3931 ] {7138aeb1-5230-462e-808d-92f83c3bdf08} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 2, should be 1: In scope SELECT reverseUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1165, line 1166) (in query: SELECT reverseUTF8(NULL, NULL);) 2025.06.13 15:40:36.267160 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 2, should be 1: In scope SELECT reverseUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:36.338958 [ 3931 ] {8cc5756d-bd3a-4b39-8864-54b5474fbdb6} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 2, should be 0: In scope SELECT revision(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1166, line 1167) (in query: SELECT revision(NULL, NULL);) 2025.06.13 15:40:36.361551 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 2, should be 0: In scope SELECT revision(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:37.232366 [ 7755 ] {f1e49654-d571-40f8-9f12-83a0dd3af1a8} 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_1749822033629950.csv: (while reading header): (in file/uri /var/lib/clickhouse/user_files/test_02961_1749822033629950.csv): While executing CSVRowInputFormat: While executing File. (ZSTD_DECODER_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39826) (comment: 02961_output_format_compress_params.sh) (query 1, line 1) (in query: SELECT count() FROM file('test_02961_1749822033629950.csv', 'CSV', 'x UInt64', 'zstd') SETTINGS zstd_window_log_max = 29;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, char const (&) [6], String&&) @ 0x0000000023b6f54f 5. ./build_docker/./src/IO/ZstdInflatingReadBuffer.cpp:63: DB::ZstdInflatingReadBuffer::nextImpl() @ 0x0000000023b6f17c 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000023b6195d 8. DB::ReadBuffer::next() @ 0x0000000017e74832 9. ./src/IO/ReadBuffer.h:96: DB::skipBOMIfExists(DB::ReadBuffer&) @ 0x000000003145f344 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:90: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x0000000031964fde 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x0000000031906046 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:40:37.272271 [ 7755 ] {} 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_1749822033629950.csv: (while reading header): (in file/uri /var/lib/clickhouse/user_files/test_02961_1749822033629950.csv): While executing CSVRowInputFormat: While executing File. (ZSTD_DECODER_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, char const (&) [6], String&&) @ 0x0000000023b6f54f 5. ./build_docker/./src/IO/ZstdInflatingReadBuffer.cpp:63: DB::ZstdInflatingReadBuffer::nextImpl() @ 0x0000000023b6f17c 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x0000000023b6195d 8. DB::ReadBuffer::next() @ 0x0000000017e74832 9. ./src/IO/ReadBuffer.h:96: DB::skipBOMIfExists(DB::ReadBuffer&) @ 0x000000003145f344 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:90: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x0000000031964fde 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x0000000031906046 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:40:37.547118 [ 3931 ] {7f27d9b5-bbbb-41f7-ba0f-c156bb9e738e} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 2, should be 1: In scope SELECT roundAge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1172, line 1173) (in query: SELECT roundAge(NULL, NULL);) 2025.06.13 15:40:37.559045 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 2, should be 1: In scope SELECT roundAge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:37.811944 [ 8432 ] {test_00601_test_3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:38920) (comment: 00601_kill_running_query.sh) (in query: SELECT sum(ignore(*)) FROM (SELECT number % 1000 AS k, groupArray(number) FROM numbers(50000000) GROUP BY k) SETTINGS max_rows_to_read = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002dee820f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002dee8126 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee88f7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:40:37.817758 [ 8432 ] {test_00601_test_3} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002dee820f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002dee8126 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee88f7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:37.988510 [ 3931 ] {e7e2eaca-9e28-420d-9aae-e98e333be138} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 2, should be 1: In scope SELECT roundDuration(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1175, line 1176) (in query: SELECT roundDuration(NULL, NULL);) 2025.06.13 15:40:38.002291 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 2, should be 1: In scope SELECT roundDuration(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:38.091139 [ 3931 ] {e63f8959-d94b-41b8-bc99-20328c275330} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 2, should be 1: In scope SELECT roundToExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1176, line 1177) (in query: SELECT roundToExp2(NULL, NULL);) 2025.06.13 15:40:38.106746 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 2, should be 1: In scope SELECT roundToExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:38.324884 [ 3931 ] {8c2eab6a-98a1-492b-9c72-edc0c610d0f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 2, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1177, line 1178) (in query: SELECT rowNumberInAllBlocks(NULL, NULL);) 2025.06.13 15:40:38.334735 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 2, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:38.442002 [ 3931 ] {9a52ffc9-932d-4807-9d0c-eae5a1e69d25} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 2, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1178, line 1179) (in query: SELECT rowNumberInBlock(NULL, NULL);) 2025.06.13 15:40:38.459226 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 2, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:38.561357 [ 3931 ] {c3a684f9-92ae-49f0-b05f-cbc1da1684b0} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1179, line 1180) (in query: SELECT row_number(NULL, NULL);) 2025.06.13 15:40:38.569712 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:40:38.976162 [ 3931 ] {4d629fbe-4e79-4c8f-ab15-c7513fb07b97} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1181, line 1183) (in query: SELECT runningAccumulate(NULL, NULL);) 2025.06.13 15:40:38.983073 [ 3931 ] {} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:40:39.069078 [ 3511 ] {bcc077e7-b41d-417a-859b-bcb4fbebc1f5::20191002_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/bcc/bcc077e7-b41d-417a-859b-bcb4fbebc1f5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:39.076306 [ 3931 ] {863ffdd0-ec72-4962-a6c5-6c590824b6ba} executeQuery: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1182, line 1184) (in query: SELECT runningConcurrency(NULL, NULL);) 2025.06.13 15:40:39.095103 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:39.151372 [ 3931 ] {c9122312-5110-409d-9e59-104154df1677} 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.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1183, line 1185) (in query: SELECT runningDifference(NULL, NULL);) 2025.06.13 15:40:39.172146 [ 3931 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:40:39.297563 [ 3511 ] {bcc077e7-b41d-417a-859b-bcb4fbebc1f5::20191002_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/bcc/bcc077e7-b41d-417a-859b-bcb4fbebc1f5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./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*) @ 0x000000002b0a61c0 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f608 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ab8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 23. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2cc3e5 24. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:308: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000030f336af 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000030f451f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f74818 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000030f63ea2 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:39.299928 [ 3511 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {bcc077e7-b41d-417a-859b-bcb4fbebc1f5::20191002_2_2_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/bcc/bcc077e7-b41d-417a-859b-bcb4fbebc1f5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./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*) @ 0x000000002b0a61c0 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f608 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ab8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 23. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2cc3e5 24. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:308: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000030f336af 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000030f451f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f74818 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000030f63ea2 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:39.300533 [ 3931 ] {4896e2c2-bfa0-4eb7-8adc-5e651140fd01} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1184, line 1186) (in query: SELECT runningDifferenceStartingWithFirstValue(NULL, NULL);) 2025.06.13 15:40:39.322579 [ 3931 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:40:39.338664 [ 4098 ] {01a9eaee-5998-499b-aaf0-e654a1a6eb33} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20191002_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/bcc/bcc077e7-b41d-417a-859b-bcb4fbebc1f5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:464: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000311cd359 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 . (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01414_mutations_and_errors.sql) (in query: /* ddl_entry=query-0000000073 */ ALTER TABLE test_11.mutation_table (MODIFY COLUMN `value` UInt64) SETTINGS mutations_sync = 2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:464: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000311cd359 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:40:39.400108 [ 3506 ] {bcc077e7-b41d-417a-859b-bcb4fbebc1f5::20191002_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/bcc/bcc077e7-b41d-417a-859b-bcb4fbebc1f5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:39.402398 [ 3506 ] {bcc077e7-b41d-417a-859b-bcb4fbebc1f5::20191002_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/bcc/bcc077e7-b41d-417a-859b-bcb4fbebc1f5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./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*) @ 0x000000002b0a61c0 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f608 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ab8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 23. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2cc3e5 24. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:308: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000030f336af 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000030f451f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f74818 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000030f63ea2 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:39.404579 [ 3506 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {bcc077e7-b41d-417a-859b-bcb4fbebc1f5::20191002_2_2_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/bcc/bcc077e7-b41d-417a-859b-bcb4fbebc1f5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./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*) @ 0x000000002b0a61c0 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f608 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ab8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 23. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2cc3e5 24. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:308: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000030f336af 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000030f451f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f74818 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000030f63ea2 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:39.434150 [ 3931 ] {bf5289f8-ba29-40f4-8c67-47f8fd8faef7} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 2, should be 3: In scope SELECT s2CapContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1185, line 1187) (in query: SELECT s2CapContains(NULL, NULL);) 2025.06.13 15:40:39.505272 [ 4098 ] {01a9eaee-5998-499b-aaf0-e654a1a6eb33} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20191002_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/bcc/bcc077e7-b41d-417a-859b-bcb4fbebc1f5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:464: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000311cd359 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 . (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39772) (comment: 01414_mutations_and_errors.sql) (query 6, line 19) (in query: ALTER TABLE mutation_table MODIFY COLUMN value UInt64 SETTINGS mutations_sync = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:464: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000311cd359 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:40:39.507825 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 2, should be 3: In scope SELECT s2CapContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:39.516026 [ 4098 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20191002_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/bcc/bcc077e7-b41d-417a-859b-bcb4fbebc1f5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:464: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000311cd359 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:464: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000311cd359 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:40:39.583997 [ 3931 ] {590d3db6-b825-41cf-8369-7165635ac6dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 2, should be 4: In scope SELECT s2CapUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1186, line 1188) (in query: SELECT s2CapUnion(NULL, NULL);) 2025.06.13 15:40:39.604930 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 2, should be 4: In scope SELECT s2CapUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:39.641518 [ 11062 ] {dd20354e-5edf-4d13-ae00-cfadb4230eca} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_3_bad', 'test', '[HIDDEN]'): Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x000000002b832500 4. ./build_docker/./src/Backups/BackupIO_S3.cpp:142: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x000000002c05527a 5. ./build_docker/./src/Backups/BackupIO_S3.cpp:184: DB::BackupReaderS3::fileExists(String const&) @ 0x000000002c054c1b 6. ./build_docker/./src/Backups/BackupImpl.cpp:428: DB::BackupImpl::readBackupMetadata() @ 0x000000002bf6d5f8 7. ./build_docker/./src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x000000002bf68815 8. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c051a99 10. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:119: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c050fde 11. ./build_docker/./src/Backups/BackupImpl.cpp:251: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf710da 12. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf70df3 13. ./build_docker/./src/Backups/BackupsWorker.cpp:621: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf3cf8a 14. ./build_docker/./src/Backups/BackupsWorker.cpp:589: DB::BackupsWorker::doBackup(std::shared_ptr, std::shared_ptr const&, String const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf3b9a1 15. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 16. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 18. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39173 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e6b 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:39.643613 [ 11062 ] {dd20354e-5edf-4d13-ae00-cfadb4230eca} BackupImpl: An error happened, the backup won't be completed 2025.06.13 15:40:39.643604 [ 8442 ] {d7dae537-60dd-4591-9dfb-7ab9e5c1fdb2} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument of function arrayWithConstant, expected Integer: In scope SELECT arrayWithConstant(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 260, line 260) (in query: SELECT arrayWithConstant(NULL, NULL);) 2025.06.13 15:40:39.651178 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument of function arrayWithConstant, expected Integer: In scope SELECT arrayWithConstant(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:39.742822 [ 8432 ] {dd20354e-5edf-4d13-ae00-cfadb4230eca} executeQuery: Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39890) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (query 1, line 1) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_3_bad', 'test', '[HIDDEN]') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x000000002b832500 4. ./build_docker/./src/Backups/BackupIO_S3.cpp:142: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x000000002c05527a 5. ./build_docker/./src/Backups/BackupIO_S3.cpp:184: DB::BackupReaderS3::fileExists(String const&) @ 0x000000002c054c1b 6. ./build_docker/./src/Backups/BackupImpl.cpp:428: DB::BackupImpl::readBackupMetadata() @ 0x000000002bf6d5f8 7. ./build_docker/./src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x000000002bf68815 8. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c051a99 10. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:119: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c050fde 11. ./build_docker/./src/Backups/BackupImpl.cpp:251: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf710da 12. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf70df3 13. ./build_docker/./src/Backups/BackupsWorker.cpp:621: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf3cf8a 14. ./build_docker/./src/Backups/BackupsWorker.cpp:589: DB::BackupsWorker::doBackup(std::shared_ptr, std::shared_ptr const&, String const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf3b9a1 15. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 16. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 18. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:40:39.769966 [ 8432 ] {} TCPHandler: Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x000000002b832500 4. ./build_docker/./src/Backups/BackupIO_S3.cpp:142: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x000000002c05527a 5. ./build_docker/./src/Backups/BackupIO_S3.cpp:184: DB::BackupReaderS3::fileExists(String const&) @ 0x000000002c054c1b 6. ./build_docker/./src/Backups/BackupImpl.cpp:428: DB::BackupImpl::readBackupMetadata() @ 0x000000002bf6d5f8 7. ./build_docker/./src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x000000002bf68815 8. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c051a99 10. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:119: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c050fde 11. ./build_docker/./src/Backups/BackupImpl.cpp:251: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf710da 12. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf70df3 13. ./build_docker/./src/Backups/BackupsWorker.cpp:621: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf3cf8a 14. ./build_docker/./src/Backups/BackupsWorker.cpp:589: DB::BackupsWorker::doBackup(std::shared_ptr, std::shared_ptr const&, String const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf3b9a1 15. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 16. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 18. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39173 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e6b 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:39.924111 [ 3931 ] {3cb17041-12ec-401c-a9cd-572e3d996e25} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 2, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1188, line 1190) (in query: SELECT s2GetNeighbors(NULL, NULL);) 2025.06.13 15:40:39.935589 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 2, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:39.972515 [ 4098 ] {f040705c-691f-4f0e-8f6f-96142cc91f1e} executeQuery: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/bcc/bcc077e7-b41d-417a-859b-bcb4fbebc1f5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39772) (comment: 01414_mutations_and_errors.sql) (query 7, line 21) (in query: SELECT distinct(value) FROM mutation_table ORDER BY value;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./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*) @ 0x000000002b0a61c0 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f608 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ab8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 23. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2cc3e5 24. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:308: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000030f336af 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000030f451f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f74818 27. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 28. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 31. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 2025.06.13 15:40:39.982544 [ 4098 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/bcc/bcc077e7-b41d-417a-859b-bcb4fbebc1f5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./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*) @ 0x000000002b0a61c0 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f608 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ab8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 23. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2cc3e5 24. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:308: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000030f336af 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000030f451f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f74818 27. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 28. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 31. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:40:40.024645 [ 3931 ] {de4dfd29-67d5-4167-b9b5-c743c7309ff1} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 2, should be 3: In scope SELECT s2RectAdd(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1189, line 1191) (in query: SELECT s2RectAdd(NULL, NULL);) 2025.06.13 15:40:40.032112 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 2, should be 3: In scope SELECT s2RectAdd(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:40.116934 [ 3510 ] {bcc077e7-b41d-417a-859b-bcb4fbebc1f5::20191002_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/bcc/bcc077e7-b41d-417a-859b-bcb4fbebc1f5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:40.119627 [ 3510 ] {bcc077e7-b41d-417a-859b-bcb4fbebc1f5::20191002_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/bcc/bcc077e7-b41d-417a-859b-bcb4fbebc1f5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./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*) @ 0x000000002b0a61c0 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f608 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ab8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 23. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2cc3e5 24. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:308: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000030f336af 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000030f451f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f74818 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000030f63ea2 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:40.128485 [ 3510 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {bcc077e7-b41d-417a-859b-bcb4fbebc1f5::20191002_2_2_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/bcc/bcc077e7-b41d-417a-859b-bcb4fbebc1f5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./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*) @ 0x000000002b0a61c0 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f608 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ab8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 23. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2cc3e5 24. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:308: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000030f336af 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000030f451f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f74818 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000030f63ea2 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:40.203770 [ 3931 ] {768c8358-7614-403f-952e-8dbde6a98bec} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 2, should be 3: In scope SELECT s2RectContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1190, line 1192) (in query: SELECT s2RectContains(NULL, NULL);) 2025.06.13 15:40:40.212179 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 2, should be 3: In scope SELECT s2RectContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:40.308118 [ 3931 ] {18b1587c-cf46-4f63-a536-86b6b64fb664} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 2, should be 4: In scope SELECT s2RectIntersection(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1191, line 1193) (in query: SELECT s2RectIntersection(NULL, NULL);) 2025.06.13 15:40:40.321568 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 2, should be 4: In scope SELECT s2RectIntersection(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:40.324179 [ 8442 ] {7c42cca6-2b21-4edf-b4aa-37427d154664} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 264, line 264) (in query: SELECT array_concat_agg(NULL, NULL);) 2025.06.13 15:40:40.332324 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:40.485920 [ 3931 ] {44749e1f-abc6-4f28-8879-24bfae26e440} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 2, should be 4: In scope SELECT s2RectUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1192, line 1194) (in query: SELECT s2RectUnion(NULL, NULL);) 2025.06.13 15:40:40.486648 [ 8442 ] {fe5e3d8b-dd74-4901-817c-4fcdf517af14} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 2, should be 1: In scope SELECT ascii(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 265, line 265) (in query: SELECT ascii(NULL, NULL);) 2025.06.13 15:40:40.497052 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 2, should be 4: In scope SELECT s2RectUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:40.502702 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 2, should be 1: In scope SELECT ascii(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:40.607926 [ 3931 ] {dbc3b822-819d-43af-b426-2c846ec0eb6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 2, should be 1: In scope SELECT s2ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1193, line 1195) (in query: SELECT s2ToGeo(NULL, NULL);) 2025.06.13 15:40:40.609316 [ 8442 ] {51367bc2-534d-400a-b9f2-02315b580f1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 2, should be 1: In scope SELECT asin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 266, line 266) (in query: SELECT asin(NULL, NULL);) 2025.06.13 15:40:40.616720 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 2, should be 1: In scope SELECT s2ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:40.634718 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 2, should be 1: In scope SELECT asin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:40.716243 [ 8442 ] {21672024-a9ac-47ad-99f1-2c30a025167e} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 2, should be 1: In scope SELECT asinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 267, line 267) (in query: SELECT asinh(NULL, NULL);) 2025.06.13 15:40:40.729997 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 2, should be 1: In scope SELECT asinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:40.811701 [ 8442 ] {805a3492-732c-47ab-97d3-9ffac7a08179} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 2, should be 1: In scope SELECT assumeNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 268, line 268) (in query: SELECT assumeNotNull(NULL, NULL);) 2025.06.13 15:40:40.847140 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 2, should be 1: In scope SELECT assumeNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:40.987997 [ 8442 ] {96ee4bdb-737f-4d05-92e4-c17f670da8bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 2, should be 1: In scope SELECT atan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 269, line 269) (in query: SELECT atan(NULL, NULL);) 2025.06.13 15:40:40.999448 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 2, should be 1: In scope SELECT atan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:41.222236 [ 8442 ] {389d0763-3c6a-4ed9-b0ad-1d06eb861e1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 2, should be 1: In scope SELECT atanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 271, line 271) (in query: SELECT atanh(NULL, NULL);) 2025.06.13 15:40:41.239368 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 2, should be 1: In scope SELECT atanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:41.513613 [ 3931 ] {74bcadd2-a5d9-4c45-b243-9ac96e420011} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1198, line 1200) (in query: SELECT sequenceNextNode(NULL, NULL);) 2025.06.13 15:40:41.528867 [ 3931 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.06.13 15:40:41.791264 [ 8442 ] {1cff3ad8-5444-4a7c-842d-fc040c3cb04e} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 2, should be 1: In scope SELECT base58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 275, line 275) (in query: SELECT base58Decode(NULL, NULL);) 2025.06.13 15:40:41.804669 [ 3931 ] {9428b1b2-d7df-4e4f-9f75-0ee36222b5b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 2, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1201, line 1203) (in query: SELECT seriesPeriodDetectFFT(NULL, NULL);) 2025.06.13 15:40:41.812059 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 2, should be 1: In scope SELECT base58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:41.818185 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 2, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:41.923451 [ 6954 ] {40795d51-c3f9-4d32-8c49-342400c8fa20} BackupsWorker: Failed to restore from backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]'): Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x000000002b832500 4. ./build_docker/./src/Backups/BackupIO_S3.cpp:142: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x000000002c05527a 5. ./build_docker/./src/Backups/BackupIO_S3.cpp:184: DB::BackupReaderS3::fileExists(String const&) @ 0x000000002c054c1b 6. ./build_docker/./src/Backups/BackupImpl.cpp:428: DB::BackupImpl::readBackupMetadata() @ 0x000000002bf6d5f8 7. ./build_docker/./src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x000000002bf68815 8. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c051a99 10. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:119: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c050fde 11. ./build_docker/./src/Backups/BackupImpl.cpp:251: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf710da 12. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf70df3 13. ./build_docker/./src/Backups/BackupImpl.cpp:751: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x000000002bf78259 14. ./build_docker/./src/Backups/BackupImpl.cpp:692: DB::BackupImpl::readFile(String const&) const @ 0x000000002bf77d92 15. ./build_docker/./src/Backups/RestorerFromBackup.cpp:451: DB::RestorerFromBackup::findTableInBackupImpl(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000002c01bf9e 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c026f1a 17. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::future std::__function::__policy_invoker (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>::__call_impl[abi:ne190107] (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe&&, char const*)::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority), std::future (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority&&) @ 0x000000002c0265f9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c01946e 6. ./build_docker/./src/Backups/RestorerFromBackup.cpp:397: DB::RestorerFromBackup::findTableInBackup(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000002c019a78 7. ./build_docker/./src/Backups/RestorerFromBackup.cpp:366: DB::RestorerFromBackup::findDatabasesAndTablesInBackup() @ 0x000000002c0160cf 8. ./build_docker/./src/Backups/RestorerFromBackup.cpp:154: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x000000002c012818 9. ./build_docker/./src/Backups/BackupsWorker.cpp:948: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf40b09 10. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 11. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 13. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39634 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e48 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:41.934645 [ 6234 ] {40795d51-c3f9-4d32-8c49-342400c8fa20} executeQuery: Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39922) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (query 1, line 1) (in query: RESTORE TABLE data FROM S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x000000002b832500 4. ./build_docker/./src/Backups/BackupIO_S3.cpp:142: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x000000002c05527a 5. ./build_docker/./src/Backups/BackupIO_S3.cpp:184: DB::BackupReaderS3::fileExists(String const&) @ 0x000000002c054c1b 6. ./build_docker/./src/Backups/BackupImpl.cpp:428: DB::BackupImpl::readBackupMetadata() @ 0x000000002bf6d5f8 7. ./build_docker/./src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x000000002bf68815 8. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c051a99 10. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:119: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c050fde 11. ./build_docker/./src/Backups/BackupImpl.cpp:251: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf710da 12. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf70df3 13. ./build_docker/./src/Backups/BackupImpl.cpp:751: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x000000002bf78259 14. ./build_docker/./src/Backups/BackupImpl.cpp:692: DB::BackupImpl::readFile(String const&) const @ 0x000000002bf77d92 15. ./build_docker/./src/Backups/RestorerFromBackup.cpp:451: DB::RestorerFromBackup::findTableInBackupImpl(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000002c01bf9e 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c026f1a 17. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:40:41.948814 [ 6234 ] {} TCPHandler: Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x000000002b832500 4. ./build_docker/./src/Backups/BackupIO_S3.cpp:142: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x000000002c05527a 5. ./build_docker/./src/Backups/BackupIO_S3.cpp:184: DB::BackupReaderS3::fileExists(String const&) @ 0x000000002c054c1b 6. ./build_docker/./src/Backups/BackupImpl.cpp:428: DB::BackupImpl::readBackupMetadata() @ 0x000000002bf6d5f8 7. ./build_docker/./src/Backups/BackupImpl.cpp:187: DB::BackupImpl::open() @ 0x000000002bf68815 8. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c051a99 10. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:119: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c050fde 11. ./build_docker/./src/Backups/BackupImpl.cpp:251: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf710da 12. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf70df3 13. ./build_docker/./src/Backups/BackupImpl.cpp:751: DB::BackupImpl::readFileImpl(std::pair> const&, bool) const @ 0x000000002bf78259 14. ./build_docker/./src/Backups/BackupImpl.cpp:692: DB::BackupImpl::readFile(String const&) const @ 0x000000002bf77d92 15. ./build_docker/./src/Backups/RestorerFromBackup.cpp:451: DB::RestorerFromBackup::findTableInBackupImpl(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000002c01bf9e 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c026f1a 17. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::future std::__function::__policy_invoker (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>::__call_impl[abi:ne190107] (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe&&, char const*)::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority), std::future (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority&&) @ 0x000000002c0265f9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c01946e 6. ./build_docker/./src/Backups/RestorerFromBackup.cpp:397: DB::RestorerFromBackup::findTableInBackup(DB::QualifiedTableName const&, bool, std::optional, 7ul, std::allocator>>> const&) @ 0x000000002c019a78 7. ./build_docker/./src/Backups/RestorerFromBackup.cpp:366: DB::RestorerFromBackup::findDatabasesAndTablesInBackup() @ 0x000000002c0160cf 8. ./build_docker/./src/Backups/RestorerFromBackup.cpp:154: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x000000002c012818 9. ./build_docker/./src/Backups/BackupsWorker.cpp:948: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf40b09 10. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 11. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 13. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39634 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e48 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:41.997538 [ 3931 ] {0b984d99-93a7-4f25-b22f-b83d571be88c} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1202, line 1204) (in query: SELECT serverTimeZone(NULL, NULL);) 2025.06.13 15:40:41.998408 [ 8442 ] {6c4077ba-ce14-4efa-aef0-915554474fe1} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 2, should be 1: In scope SELECT base58Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 276, line 276) (in query: SELECT base58Encode(NULL, NULL);) 2025.06.13 15:40:42.018983 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:42.022279 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 2, should be 1: In scope SELECT base58Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:42.115281 [ 8442 ] {3c52663c-9398-4007-a585-0ddf054fa3a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT base64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 277, line 277) (in query: SELECT base64Decode(NULL, NULL);) 2025.06.13 15:40:42.124295 [ 3931 ] {957162de-2d5f-49fd-9f5c-ab3169c1cbeb} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1203, line 1205) (in query: SELECT serverTimezone(NULL, NULL);) 2025.06.13 15:40:42.124781 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT base64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:42.149503 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:42.286454 [ 3931 ] {2235cc45-33b1-4eae-9921-6a36447fa0a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 2, should be 0: In scope SELECT serverUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1204, line 1206) (in query: SELECT serverUUID(NULL, NULL);) 2025.06.13 15:40:42.292823 [ 8442 ] {6a09abc6-5d74-4f24-a8be-a07bd3a55f72} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT base64Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 278, line 278) (in query: SELECT base64Encode(NULL, NULL);) 2025.06.13 15:40:42.300451 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 2, should be 0: In scope SELECT serverUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:42.313682 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT base64Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:42.456969 [ 3931 ] {48c203d4-c652-4bc5-b383-b1e979335ac1} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 2, should be 0: In scope SELECT shardCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1205, line 1207) (in query: SELECT shardCount(NULL, NULL);) 2025.06.13 15:40:42.462927 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 2, should be 0: In scope SELECT shardCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:42.621599 [ 8442 ] {4cccc627-e577-4119-b7fd-939e6589fc49} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 279, line 279) (in query: SELECT base64URLDecode(NULL, NULL);) 2025.06.13 15:40:42.630779 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:42.643582 [ 3931 ] {92bd070e-d1b1-46b9-98db-c8c77aa1daef} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 2, should be 0: In scope SELECT shardNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1206, line 1208) (in query: SELECT shardNum(NULL, NULL);) 2025.06.13 15:40:42.743215 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 2, should be 0: In scope SELECT shardNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:42.779473 [ 8442 ] {a849eeb7-0edd-4160-9bd2-15535ded561f} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 280, line 280) (in query: SELECT base64URLEncode(NULL, NULL);) 2025.06.13 15:40:42.786179 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:42.786550 [ 3931 ] {6faba503-2524-42ed-a726-dfe6192e3f70} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 2, should be 0: In scope SELECT showCertificate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1207, line 1209) (in query: SELECT showCertificate(NULL, NULL);) 2025.06.13 15:40:42.826476 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 2, should be 0: In scope SELECT showCertificate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:42.900881 [ 8442 ] {c4aeab58-534a-445f-a9ba-65824061ab88} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 2, should be 1: In scope SELECT basename(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 281, line 281) (in query: SELECT basename(NULL, NULL);) 2025.06.13 15:40:42.919309 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 2, should be 1: In scope SELECT basename(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:42.973606 [ 3931 ] {4a7796b3-f6bf-40c8-b002-846f6ceec29c} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 2, should be 1: In scope SELECT sigmoid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1208, line 1210) (in query: SELECT sigmoid(NULL, NULL);) 2025.06.13 15:40:42.996517 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 2, should be 1: In scope SELECT sigmoid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:43.087997 [ 3931 ] {82fc3f18-4911-46e0-8c85-565fc331edc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 2, should be 1: In scope SELECT sign(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1209, line 1211) (in query: SELECT sign(NULL, NULL);) 2025.06.13 15:40:43.098338 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 2, should be 1: In scope SELECT sign(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:43.101990 [ 8442 ] {4dfb07be-b7e8-4d77-b74c-42c27167b325} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 2, should be 1: In scope SELECT bin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 282, line 282) (in query: SELECT bin(NULL, NULL);) 2025.06.13 15:40:43.106108 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 2, should be 1: In scope SELECT bin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:43.384388 [ 8442 ] {705e5071-a7b3-4fcf-94ed-5075dea520fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 2, should be 1: In scope SELECT bitCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 284, line 284) (in query: SELECT bitCount(NULL, NULL);) 2025.06.13 15:40:43.402551 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 2, should be 1: In scope SELECT bitCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:43.677597 [ 9636 ] {495c1569-41fa-4ef8-ac2a-c4f979b4e24a} 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.20286.altinityantalya (altinity build)) (from [::1]:48460) (comment: 00623_replicated_truncate_table_zookeeper_long.sql) (query 4, line 8) (in query: CREATE TABLE replicated_truncate1 (`d` Date, `k` UInt64, `i32` Int32) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_00623/truncate', 'r1') PARTITION BY toYYYYMM(d) ORDER BY k SETTINGS index_granularity = 4297, min_bytes_for_wide_part = 535692385, 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 = 78908775, compact_parts_max_bytes_to_buffer = 147470122, compact_parts_max_granules_to_buffer = 195, compact_parts_merge_max_bytes_to_prefetch_part = 1467513, merge_max_block_size = 18681, old_parts_lifetime = 473., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 65, min_merge_bytes_to_use_direct_io = 1783315851, index_granularity_bytes = 17404407, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 98140, primary_key_compress_block_size = 10600, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:43.685326 [ 8442 ] {8aef2acd-9ea1-4ab0-abe8-5b78868e8421} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 2, should be 1: In scope SELECT bitNot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 286, line 286) (in query: SELECT bitNot(NULL, NULL);) 2025.06.13 15:40:43.710233 [ 9636 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:43.738268 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 2, should be 1: In scope SELECT bitNot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:43.996212 [ 8442 ] {26c684cb-f553-4821-84f0-4c224da1ec13} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 2, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 288, line 288) (in query: SELECT bitPositionsToArray(NULL, NULL);) 2025.06.13 15:40:44.001845 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 2, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:44.610378 [ 3931 ] {6161a7eb-1274-49b7-8617-ccd9ad78ea2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 2, should be 1: In scope SELECT sin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1218, line 1220) (in query: SELECT sin(NULL, NULL);) 2025.06.13 15:40:44.637682 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 2, should be 1: In scope SELECT sin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:44.978704 [ 3931 ] {c3a2f162-f91f-4dee-ad52-4fe1960ec436} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 2, should be 1: In scope SELECT sinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1220, line 1222) (in query: SELECT sinh(NULL, NULL);) 2025.06.13 15:40:45.001036 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 2, should be 1: In scope SELECT sinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:46.343403 [ 8442 ] {8dc86e95-13f4-4f03-a6c1-17426c9e8a14} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 2, should be 1: In scope SELECT bitmapBuild(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 302, line 302) (in query: SELECT bitmapBuild(NULL, NULL);) 2025.06.13 15:40:46.354461 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 2, should be 1: In scope SELECT bitmapBuild(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:46.444082 [ 3931 ] {d1da6ad1-3a75-4b40-8c6d-b47fbbe10f10} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 2, should be 1: In scope SELECT sleep(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1229, line 1231) (in query: SELECT sleep(NULL, NULL);) 2025.06.13 15:40:46.445288 [ 11509 ] {d8689154-3385-42dc-b284-2491d7b32451} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_6_bad', 'test', '[HIDDEN]', 'foo'): Code: 42. DB::Exception: Backup S3 requires 1 or 3 arguments: url, [access_key_id, secret_access_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:79: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c0515a1 6. ./build_docker/./src/Backups/BackupsWorker.cpp:531: DB::BackupsWorker::openBackupForWriting(DB::BackupInfo const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr const&) const @ 0x000000002bf3a516 7. ./build_docker/./src/Backups/BackupsWorker.cpp:416: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf50308 8. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 10. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39173 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e6b 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:46.453171 [ 8442 ] {bb487bc1-134c-476e-832d-a59e7c1a387a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 2, should be 1: In scope SELECT bitmapCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 303, line 303) (in query: SELECT bitmapCardinality(NULL, NULL);) 2025.06.13 15:40:46.455514 [ 6234 ] {d8689154-3385-42dc-b284-2491d7b32451} executeQuery: Code: 42. DB::Exception: Backup S3 requires 1 or 3 arguments: url, [access_key_id, secret_access_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48560) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (query 1, line 1) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_6_bad', 'test', '[HIDDEN]', 'foo') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]'), use_same_s3_credentials_for_base_backup = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:79: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c0515a1 6. ./build_docker/./src/Backups/BackupsWorker.cpp:531: DB::BackupsWorker::openBackupForWriting(DB::BackupInfo const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr const&) const @ 0x000000002bf3a516 7. ./build_docker/./src/Backups/BackupsWorker.cpp:416: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf50308 8. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 10. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:40:46.458148 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 2, should be 1: In scope SELECT sleep(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:46.474335 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 2, should be 1: In scope SELECT bitmapCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:46.478249 [ 6234 ] {} TCPHandler: Code: 42. DB::Exception: Backup S3 requires 1 or 3 arguments: url, [access_key_id, secret_access_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:79: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c0515a1 6. ./build_docker/./src/Backups/BackupsWorker.cpp:531: DB::BackupsWorker::openBackupForWriting(DB::BackupInfo const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr const&) const @ 0x000000002bf3a516 7. ./build_docker/./src/Backups/BackupsWorker.cpp:416: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf50308 8. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 10. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39173 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e6b 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:46.611008 [ 3931 ] {1e3e64a1-2be0-4ff3-b37b-42dbed3c39d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 2, should be 1: In scope SELECT sleepEachRow(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1230, line 1232) (in query: SELECT sleepEachRow(NULL, NULL);) 2025.06.13 15:40:46.625749 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 2, should be 1: In scope SELECT sleepEachRow(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:46.822978 [ 8101 ] {7a7450ae-8088-43f4-b9af-3ecccbacb801} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value3` UInt64)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01413_allow_non_metadata_alters.sql) (in query: /* ddl_entry=query-0000000077 */ ALTER TABLE test_11.non_metadata_alters (MODIFY COLUMN `value3` UInt64)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:46.866479 [ 8101 ] {7a7450ae-8088-43f4-b9af-3ecccbacb801} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value3` UInt64)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48524) (comment: 01413_allow_non_metadata_alters.sql) (query 4, line 17) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value3 UInt64;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:46.872669 [ 8101 ] {} TCPHandler: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value3` UInt64)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:47.142566 [ 8442 ] {15b684e6-459f-4afe-b93d-4abf4fe7d8aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 2, should be 1: In scope SELECT bitmapMax(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 307, line 307) (in query: SELECT bitmapMax(NULL, NULL);) 2025.06.13 15:40:47.175729 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 2, should be 1: In scope SELECT bitmapMax(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:47.383498 [ 8442 ] {63bdc24e-06f6-4de5-8ce1-133aad7d57ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 2, should be 1: In scope SELECT bitmapMin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 308, line 308) (in query: SELECT bitmapMin(NULL, NULL);) 2025.06.13 15:40:47.392854 [ 8101 ] {97f32df9-67b4-44bb-ad41-49a157cff10c} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value1` UInt32)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01413_allow_non_metadata_alters.sql) (in query: /* ddl_entry=query-0000000078 */ ALTER TABLE test_11.non_metadata_alters (MODIFY COLUMN `value1` UInt32)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:47.405266 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 2, should be 1: In scope SELECT bitmapMin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:47.501164 [ 3931 ] {45ca8fcb-300c-4ec2-af34-6a1f31330e31} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 2, should be 1: In scope SELECT soundex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1235, line 1237) (in query: SELECT soundex(NULL, NULL);) 2025.06.13 15:40:47.504358 [ 8101 ] {97f32df9-67b4-44bb-ad41-49a157cff10c} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value1` UInt32)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48524) (comment: 01413_allow_non_metadata_alters.sql) (query 5, line 19) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value1 UInt32;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:47.509622 [ 8101 ] {} TCPHandler: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value1` UInt32)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:47.513977 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 2, should be 1: In scope SELECT soundex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:47.645666 [ 3931 ] {ca92f01a-5696-4a90-8889-156166368257} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 2, should be 1: In scope SELECT space(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1236, line 1238) (in query: SELECT space(NULL, NULL);) 2025.06.13 15:40:47.671904 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 2, should be 1: In scope SELECT space(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:47.843645 [ 8442 ] {f42598c3-797f-4c7d-99ed-38d5d2a51c28} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetInRange(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 311, line 311) (in query: SELECT bitmapSubsetInRange(NULL, NULL);) 2025.06.13 15:40:47.864499 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetInRange(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:47.968050 [ 8442 ] {17048061-ceb8-459b-a305-2e35016c3300} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetLimit(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 312, line 312) (in query: SELECT bitmapSubsetLimit(NULL, NULL);) 2025.06.13 15:40:47.979996 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetLimit(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:47.990547 [ 8101 ] {ff99054e-3d3f-4394-a76b-076c8354e6c7} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value4` Date)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01413_allow_non_metadata_alters.sql) (in query: /* ddl_entry=query-0000000079 */ ALTER TABLE test_11.non_metadata_alters (MODIFY COLUMN `value4` Date)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:48.040680 [ 8101 ] {ff99054e-3d3f-4394-a76b-076c8354e6c7} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value4` Date)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48524) (comment: 01413_allow_non_metadata_alters.sql) (query 6, line 21) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value4 Date;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:48.047020 [ 8101 ] {} TCPHandler: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value4` Date)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:48.071516 [ 8442 ] {4af349e7-1399-42e8-808e-c002b5bfe80a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 2, should be 1: In scope SELECT bitmapToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 313, line 313) (in query: SELECT bitmapToArray(NULL, NULL);) 2025.06.13 15:40:48.098075 [ 4947 ] {f9306af3-9fcf-4e6c-a72c-2f0ef3365ac4} BackupsWorker: Failed to make backup Disk('backups', 'test_1/backup_2'): Code: 36. DB::Exception: use_same_s3_credentials_for_base_backup supported only for S3, got Disk('backups', 'test_1/backup_2'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupInfo.cpp:110: DB::BackupInfo::copyS3CredentialsTo(DB::BackupInfo&) const @ 0x000000002bf35c01 6. ./build_docker/./src/Backups/BackupImpl.cpp:248: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf70fc6 7. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf70df3 8. ./build_docker/./src/Backups/BackupsWorker.cpp:621: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf3cf8a 9. ./build_docker/./src/Backups/BackupsWorker.cpp:589: DB::BackupsWorker::doBackup(std::shared_ptr, std::shared_ptr const&, String const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf3b9a1 10. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 11. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 13. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39173 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e6b 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:48.107336 [ 4947 ] {f9306af3-9fcf-4e6c-a72c-2f0ef3365ac4} BackupImpl: An error happened, the backup won't be completed 2025.06.13 15:40:48.118289 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 2, should be 1: In scope SELECT bitmapToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:48.122693 [ 6234 ] {f9306af3-9fcf-4e6c-a72c-2f0ef3365ac4} executeQuery: Code: 36. DB::Exception: use_same_s3_credentials_for_base_backup supported only for S3, got Disk('backups', 'test_1/backup_2'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48600) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (query 1, line 1) (in query: BACKUP TABLE data TO Disk('backups', 'test_1/backup_2') SETTINGS use_same_s3_credentials_for_base_backup=1, base_backup=Disk('backups', 'test_1/backup_1')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupInfo.cpp:110: DB::BackupInfo::copyS3CredentialsTo(DB::BackupInfo&) const @ 0x000000002bf35c01 6. ./build_docker/./src/Backups/BackupImpl.cpp:248: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf70fc6 7. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf70df3 8. ./build_docker/./src/Backups/BackupsWorker.cpp:621: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf3cf8a 9. ./build_docker/./src/Backups/BackupsWorker.cpp:589: DB::BackupsWorker::doBackup(std::shared_ptr, std::shared_ptr const&, String const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf3b9a1 10. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 11. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 13. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:48.137276 [ 6234 ] {} TCPHandler: Code: 36. DB::Exception: use_same_s3_credentials_for_base_backup supported only for S3, got Disk('backups', 'test_1/backup_2'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupInfo.cpp:110: DB::BackupInfo::copyS3CredentialsTo(DB::BackupInfo&) const @ 0x000000002bf35c01 6. ./build_docker/./src/Backups/BackupImpl.cpp:248: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000002bf70fc6 7. ./build_docker/./src/Backups/BackupImpl.cpp:240: DB::BackupImpl::getBaseBackup() const @ 0x000000002bf70df3 8. ./build_docker/./src/Backups/BackupsWorker.cpp:621: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf3cf8a 9. ./build_docker/./src/Backups/BackupsWorker.cpp:589: DB::BackupsWorker::doBackup(std::shared_ptr, std::shared_ptr const&, String const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf3b9a1 10. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 11. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 13. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39173 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e6b 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:48.218136 [ 8442 ] {562e2a03-5ce7-4d72-a205-48d7de701792} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 2, should be 3: In scope SELECT bitmapTransform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 314, line 314) (in query: SELECT bitmapTransform(NULL, NULL);) 2025.06.13 15:40:48.232014 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 2, should be 3: In scope SELECT bitmapTransform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:48.358900 [ 8101 ] {e5a220eb-6a54-4def-ac76-a53e00979cf7} executeQuery: Code: 524. DB::Exception: The following alter commands: '(DROP COLUMN value4)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01413_allow_non_metadata_alters.sql) (in query: /* ddl_entry=query-0000000080 */ ALTER TABLE test_11.non_metadata_alters (DROP COLUMN value4)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:48.399624 [ 8101 ] {e5a220eb-6a54-4def-ac76-a53e00979cf7} executeQuery: Code: 524. DB::Exception: The following alter commands: '(DROP COLUMN value4)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48524) (comment: 01413_allow_non_metadata_alters.sql) (query 7, line 23) (in query: ALTER TABLE non_metadata_alters DROP COLUMN value4;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:48.411018 [ 8101 ] {} TCPHandler: Code: 524. DB::Exception: The following alter commands: '(DROP COLUMN value4)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:48.493884 [ 8442 ] {f01f3ae6-5eaa-4ac7-94b9-3333fda8962f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 2, should be 1: In scope SELECT bitmaskToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 317, line 317) (in query: SELECT bitmaskToArray(NULL, NULL);) 2025.06.13 15:40:48.506734 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 2, should be 1: In scope SELECT bitmaskToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:48.663925 [ 8442 ] {68d8687c-22bc-4a88-a63a-85c485a4c6f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 2, should be 1: In scope SELECT bitmaskToList(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 318, line 318) (in query: SELECT bitmaskToList(NULL, NULL);) 2025.06.13 15:40:48.681038 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 2, should be 1: In scope SELECT bitmaskToList(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:48.748330 [ 8101 ] {8b14f151-72f7-400d-8fe6-66c162abbaa7} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value2` Enum8('x' = 5, 'y' = 6))' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01413_allow_non_metadata_alters.sql) (in query: /* ddl_entry=query-0000000081 */ ALTER TABLE test_11.non_metadata_alters (MODIFY COLUMN `value2` Enum8('x' = 5, 'y' = 6))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:48.785793 [ 8442 ] {f9d8f8ce-8624-4fbc-9e14-168e639f114d} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 2, should be 0: In scope SELECT blockNumber(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 319, line 319) (in query: SELECT blockNumber(NULL, NULL);) 2025.06.13 15:40:48.787083 [ 8101 ] {8b14f151-72f7-400d-8fe6-66c162abbaa7} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value2` Enum8('x' = 5, 'y' = 6))' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48524) (comment: 01413_allow_non_metadata_alters.sql) (query 8, line 25) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value2 Enum8('x' = 5, 'y' = 6);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:48.791592 [ 8101 ] {} TCPHandler: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value2` Enum8('x' = 5, 'y' = 6))' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:48.800417 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 2, should be 0: In scope SELECT blockNumber(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:48.887253 [ 8432 ] {3d5d5a8e-dbb9-4b36-a746-38d705ecac20} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 9.71 MiB (attempt to allocate chunk of 1.14 MiB bytes), maximum: 9.54 MiB.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39902) (comment: 03214_count_distinct_null_key_memory_leak.sql) (query 4, line 16) (in query: SELECT count(distinct b) FROM testnull GROUP BY a SETTINGS max_memory_usage = 10000000;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239910e3 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc82e6 10. ./src/Common/PODArray.h:248: DB::ColumnString::shrinkToFit() @ 0x000000002fd249e4 11. ./build_docker/./src/Columns/ColumnNullable.cpp:757: DB::ColumnNullable::shrinkToFit() @ 0x000000002fcae075 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:201: DB::MergeTreeReadTask::read() @ 0x0000000030f6f0f7 13. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321ee091 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:48.893330 [ 8432 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 9.71 MiB (attempt to allocate chunk of 1.14 MiB bytes), maximum: 9.54 MiB.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239910e3 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc82e6 10. ./src/Common/PODArray.h:248: DB::ColumnString::shrinkToFit() @ 0x000000002fd249e4 11. ./build_docker/./src/Columns/ColumnNullable.cpp:757: DB::ColumnNullable::shrinkToFit() @ 0x000000002fcae075 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:201: DB::MergeTreeReadTask::read() @ 0x0000000030f6f0f7 13. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321ee091 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:40:49.066219 [ 8442 ] {2d4b89ae-ecc3-48c6-9b59-4ae253f77e90} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 2, should be 0: In scope SELECT blockSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 321, line 321) (in query: SELECT blockSize(NULL, NULL);) 2025.06.13 15:40:49.081586 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 2, should be 0: In scope SELECT blockSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:49.181786 [ 8101 ] {ca0af330-ef63-473f-a3f4-effca244a6cc} executeQuery: Code: 524. DB::Exception: The following alter commands: '(RENAME COLUMN value4 TO renamed_value4)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01413_allow_non_metadata_alters.sql) (in query: /* ddl_entry=query-0000000082 */ ALTER TABLE test_11.non_metadata_alters (RENAME COLUMN value4 TO renamed_value4)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:49.251250 [ 8101 ] {ca0af330-ef63-473f-a3f4-effca244a6cc} executeQuery: Code: 524. DB::Exception: The following alter commands: '(RENAME COLUMN value4 TO renamed_value4)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48524) (comment: 01413_allow_non_metadata_alters.sql) (query 9, line 27) (in query: ALTER TABLE non_metadata_alters RENAME COLUMN value4 TO renamed_value4;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:49.255529 [ 8101 ] {} TCPHandler: Code: 524. DB::Exception: The following alter commands: '(RENAME COLUMN value4 TO renamed_value4)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:49.281034 [ 8442 ] {8f58f033-f833-4a37-a371-f5e9330ba845} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 2, should be 0: In scope SELECT buildId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 323, line 323) (in query: SELECT buildId(NULL, NULL);) 2025.06.13 15:40:49.286522 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 2, should be 0: In scope SELECT buildId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:49.447829 [ 3931 ] {cfd867ea-fb4b-4afc-875b-086b9c910b0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 2, should be 1: In scope SELECT sqidDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1246, line 1248) (in query: SELECT sqidDecode(NULL, NULL);) 2025.06.13 15:40:49.455213 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 2, should be 1: In scope SELECT sqidDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:49.655600 [ 3931 ] {4f748f78-73a3-4136-a06f-b8554004a812} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 2, should be 1: In scope SELECT sqrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1248, line 1250) (in query: SELECT sqrt(NULL, NULL);) 2025.06.13 15:40:49.673762 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 2, should be 1: In scope SELECT sqrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:49.680982 [ 8101 ] {e4635157-a205-4eb6-8084-1fb4efdc0a27} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MATERIALIZE TTL)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01413_allow_non_metadata_alters.sql) (in query: /* ddl_entry=query-0000000083 */ ALTER TABLE test_11.non_metadata_alters (MODIFY COLUMN `value3` UInt16 TTL value5 + toIntervalDay(5))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:49.792165 [ 8101 ] {e4635157-a205-4eb6-8084-1fb4efdc0a27} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MATERIALIZE TTL)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48524) (comment: 01413_allow_non_metadata_alters.sql) (query 10, line 29) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value3 UInt16 TTL value5 + INTERVAL 5 DAY;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:49.796046 [ 8101 ] {} TCPHandler: Code: 524. DB::Exception: The following alter commands: '(MATERIALIZE TTL)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3516: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030ccc56b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:49.883533 [ 8442 ] {cbff3d99-f371-40c5-8734-b4dcf8edaa18} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 327, line 327) (in query: SELECT byteSwap(NULL, NULL);) 2025.06.13 15:40:49.889449 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:50.219880 [ 8442 ] {bb9032e5-e424-4f61-b65b-8ae2ffbcac36} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 330, line 330) (in query: SELECT caseWithoutExpr(NULL, NULL);) 2025.06.13 15:40:50.239914 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:50.338892 [ 8442 ] {9758ece1-6a5b-4c61-b0a7-d20aa1e1e459} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 331, line 331) (in query: SELECT caseWithoutExpression(NULL, NULL);) 2025.06.13 15:40:50.359154 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:50.495054 [ 8442 ] {1af27427-58be-40d9-8732-3b42dbeda111} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 332, line 332) (in query: SELECT catboostEvaluate(NULL, NULL);) 2025.06.13 15:40:50.505278 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:50.681969 [ 8442 ] {1c8e0304-7ee8-4ae6-86bc-629cf4b39a37} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 333, line 333) (in query: SELECT categoricalInformationValue(NULL, NULL);) 2025.06.13 15:40:50.698052 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:50.785499 [ 3931 ] {c4a67c14-438e-4972-bc21-9cb731d4e119} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1255, line 1257) (in query: SELECT stem(NULL, NULL);) 2025.06.13 15:40:50.812106 [ 3931 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:40:50.820822 [ 8442 ] {94b936ee-185b-43a2-9a1e-0ba873ecf019} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 2, should be 1: In scope SELECT cbrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 334, line 334) (in query: SELECT cbrt(NULL, NULL);) 2025.06.13 15:40:50.828840 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 2, should be 1: In scope SELECT cbrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:51.577733 [ 8099 ] {a5acae8f-4d9b-454a-9d2b-c04070db7b9c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57662) (comment: 01395_limit_more_cases_random.sh) (query 46, line 316) (in query: WITH count() AS c, min(number) AS first, max(number) AS last SELECT throwIf(first != (20 < 92 AND 83 > 0 ? 20 : 0)), throwIf(last != (20 < 92 AND 83 > 0 ? least(92 - 1, 20 + 83 - 1) : 0)), throwIf((c != 0 OR first != 0 OR last != 0) AND (c != last - first + 1)) FROM (SELECT * FROM numbers(92) LIMIT 20, 83);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:40:51.603482 [ 8099 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:40:51.961911 [ 6193 ] {f5078379-0c55-4aec-8c3a-b44946c05097} executeQuery: Code: 36. DB::Exception: Encrypted data is smaller than the size of additional data for AEAD mode, cannot decrypt.: In scope SELECT decrypt('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48682) (comment: 01776_decrypt_aead_size_check.sql) (query 1, line 4) (in query: SELECT decrypt('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001a060cf9 6. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a05f04a 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:40:52.026890 [ 6193 ] {} TCPHandler: Code: 36. DB::Exception: Encrypted data is smaller than the size of additional data for AEAD mode, cannot decrypt.: In scope SELECT decrypt('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000001a060cf9 6. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a05f04a 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:40:52.223958 [ 3931 ] {66642670-c8b6-4e2c-bcef-12c5061d0566} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 2, should be 1: In scope SELECT stringToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1262, line 1264) (in query: SELECT stringToH3(NULL, NULL);) 2025.06.13 15:40:52.258933 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 2, should be 1: In scope SELECT stringToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:52.378091 [ 3931 ] {ce8124d5-dcc9-46d0-87f1-a2d244828d3c} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToCapnProtoSchema, expected constant string: In scope SELECT structureToCapnProtoSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1263, line 1265) (in query: SELECT structureToCapnProtoSchema(NULL, NULL);) 2025.06.13 15:40:52.388650 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToCapnProtoSchema, expected constant string: In scope SELECT structureToCapnProtoSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:52.485238 [ 3931 ] {7487ae6b-d9e6-4915-9d3a-776e9f411f5d} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToProtobufSchema, expected constant string: In scope SELECT structureToProtobufSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1264, line 1266) (in query: SELECT structureToProtobufSchema(NULL, NULL);) 2025.06.13 15:40:52.492014 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToProtobufSchema, expected constant string: In scope SELECT structureToProtobufSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:52.818369 [ 3931 ] {904d27ec-713b-406f-bab1-b50e3d7f52b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 2, should be 3: In scope SELECT subBitmap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1266, line 1268) (in query: SELECT subBitmap(NULL, NULL);) 2025.06.13 15:40:52.833228 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 2, should be 3: In scope SELECT subBitmap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:52.928109 [ 8442 ] {db64ff6c-3c49-4897-aa77-0c64bfbb156c} executeQuery: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 2, should be 3: In scope SELECT clamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 345, line 345) (in query: SELECT clamp(NULL, NULL);) 2025.06.13 15:40:52.938370 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 2, should be 3: In scope SELECT clamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:53.201959 [ 6234 ] {f9ee936c-31f5-438e-a38a-00993042349d} executeQuery: Code: 290. DB::Exception: Maximum limit of 3 projection(s) exceeded. (LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48680) (comment: 02934_merge_tree_max_projections.sql) (query 6, line 10) (in query: ALTER TABLE test_max_mt_projections_alter ADD PROJECTION p4 (SELECT c2, c3 ORDER BY c2, c3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c81c0f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7b5b4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc921d 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:53.208364 [ 6234 ] {} TCPHandler: Code: 290. DB::Exception: Maximum limit of 3 projection(s) exceeded. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c81c0f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7b5b4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc921d 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:53.405279 [ 3931 ] {f088633c-54ac-47d8-96c1-85fa7e11a9d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT substringIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1270, line 1272) (in query: SELECT substringIndex(NULL, NULL);) 2025.06.13 15:40:53.415961 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT substringIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:53.553874 [ 3931 ] {d258319c-7766-44aa-abc2-93afcde5397f} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 2, should be 3: In scope SELECT substringIndexUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1271, line 1273) (in query: SELECT substringIndexUTF8(NULL, NULL);) 2025.06.13 15:40:53.568593 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 2, should be 3: In scope SELECT substringIndexUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:54.369334 [ 8442 ] {8d7c82c1-ecad-4486-b37e-66a5c5f2416c} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connectionId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 353, line 353) (in query: SELECT connectionId(NULL, NULL);) 2025.06.13 15:40:54.381351 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connectionId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:54.520606 [ 8442 ] {6522ca7a-a815-4a7c-a31d-11be79350de9} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connection_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 354, line 354) (in query: SELECT connection_id(NULL, NULL);) 2025.06.13 15:40:54.533668 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connection_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:54.871527 [ 8442 ] {19dc3582-5b34-4053-a552-b495dfba0563} executeQuery: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 2, should be 3: In scope SELECT convertCharset(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 356, line 356) (in query: SELECT convertCharset(NULL, NULL);) 2025.06.13 15:40:54.881170 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 2, should be 3: In scope SELECT convertCharset(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:55.027987 [ 6234 ] {3dae076a-36f2-4eb9-b36a-928902e02581} executeQuery: Code: 290. DB::Exception: Maximum limit of 1 projection(s) exceeded. (LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48680) (comment: 02934_merge_tree_max_projections.sql) (query 11, line 20) (in query: CREATE TABLE test_max_mt_projections_create (`c1` UInt32, `c2` UInt32, PROJECTION p1 (SELECT c1, c2 ORDER BY c2), PROJECTION p2 (SELECT c2 ORDER BY c2)) ENGINE = MergeTree ORDER BY c1 SETTINGS max_projections = 1, index_granularity = 5483, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.7700508832931519, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 489091534, compact_parts_max_bytes_to_buffer = 155257463, compact_parts_max_granules_to_buffer = 251, compact_parts_merge_max_bytes_to_prefetch_part = 32737561, merge_max_block_size = 271, old_parts_lifetime = 131., prefer_fetch_merged_part_size_threshold = 3363425237, 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 = 9349510, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 8907, primary_key_compress_block_size = 33930, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c81c0f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7b5b4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:55.033408 [ 6234 ] {} TCPHandler: Code: 290. DB::Exception: Maximum limit of 1 projection(s) exceeded. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c81c0f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7b5b4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:55.063410 [ 4098 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:55.065906 [ 4098 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:55.271221 [ 6234 ] {2a77c28b-4d7d-45cb-95bd-c9111fa85912} executeQuery: Code: 290. DB::Exception: Maximum limit of 0 projection(s) exceeded. (LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48680) (comment: 02934_merge_tree_max_projections.sql) (query 12, line 26) (in query: CREATE TABLE test_max_mt_projections_create (`c1` UInt32, `c2` UInt32, PROJECTION p (SELECT c1, c2 ORDER BY c2)) ENGINE = MergeTree ORDER BY c1 SETTINGS max_projections = 0, index_granularity = 5483, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.7700508832931519, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 489091534, compact_parts_max_bytes_to_buffer = 155257463, compact_parts_max_granules_to_buffer = 251, compact_parts_merge_max_bytes_to_prefetch_part = 32737561, merge_max_block_size = 271, old_parts_lifetime = 131., prefer_fetch_merged_part_size_threshold = 3363425237, 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 = 9349510, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 8907, primary_key_compress_block_size = 33930, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c81c0f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7b5b4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:55.276436 [ 6234 ] {} TCPHandler: Code: 290. DB::Exception: Maximum limit of 0 projection(s) exceeded. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c81c0f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7b5b4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:40:55.391238 [ 9644 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:55.392359 [ 9644 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:55.527005 [ 9636 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:55.544605 [ 7755 ] {72b539c7-30b4-4365-b493-2c4721e07829} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), '^data$') does not support column __table1._table in PREWHERE. In query SELECT 1 FROM merge(currentDatabase(), '^data$') PREWHERE _table IN (NULL). (ILLEGAL_PREWHERE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56874) (comment: 01931_storage_merge_no_columns.sql) (query 3, line 3) (in query: select 1 from merge(currentDatabase(), '^data$') prewhere _table in (NULL);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15d80f 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15cdb6 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15cdb6 8. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x000000002d158eee 9. ./build_docker/./src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6bb69 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:40:55.546481 [ 8432 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:40:55.551329 [ 7755 ] {} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), '^data$') does not support column __table1._table in PREWHERE. In query SELECT 1 FROM merge(currentDatabase(), '^data$') PREWHERE _table IN (NULL). (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15d80f 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15cdb6 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002d15cdb6 8. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x000000002d158eee 9. ./build_docker/./src/Planner/Planner.cpp:1501: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6bb69 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:40:55.724357 [ 9636 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:40:55.731945 [ 9636 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:40:55.808336 [ 8442 ] {88121450-9ebf-4443-a9a0-1322bcd0e562} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 2, should be 1: In scope SELECT cos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 360, line 360) (in query: SELECT cos(NULL, NULL);) 2025.06.13 15:40:55.813178 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 2, should be 1: In scope SELECT cos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:55.813352 [ 7279 ] {180ff43a-4513-4846-85cc-c79388489fa9} executeQuery: Code: 57. DB::Exception: Table test_9.test1_00395 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48644) (comment: 00395_nullable.sql) (query 29, line 81) (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 = StripeLog;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:40:55.819655 [ 6234 ] {c4cec4e0-4b25-4088-a979-ede379ec505d} executeQuery: Code: 290. DB::Exception: Maximum limit of 1 projection(s) exceeded. (LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48680) (comment: 02934_merge_tree_max_projections.sql) (query 14, line 36) (in query: ALTER TABLE test_max_mt_projections_create ADD PROJECTION p2 (SELECT c2 ORDER BY c2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c81c0f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7b5b4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc921d 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:55.826293 [ 3821 ] {c2d2679f-2755-4c1a-8071-dfd78ac2967e} executeQuery: Code: 452. DB::Exception: Received from localhost:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56898) (comment: 02287_legacy_column_name_of_tuple_literal_over_distributed.sql) (query 3, line 4) (in query: select if(in(dummy, tuple(0, 1)), 'ok', 'ok') from remote('localhost', system.one);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:40:55.843736 [ 7279 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.test1_00395 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:40:55.854804 [ 6234 ] {} TCPHandler: Code: 290. DB::Exception: Maximum limit of 1 projection(s) exceeded. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c81c0f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:838: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7b5b4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3860: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc921d 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:40:55.856782 [ 3821 ] {} TCPHandler: Code: 452. DB::Exception: Received from localhost:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:40:55.941648 [ 8442 ] {288202bb-e2ac-4c46-9fda-006e4ee989c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 2, should be 1: In scope SELECT cosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 361, line 361) (in query: SELECT cosh(NULL, NULL);) 2025.06.13 15:40:55.946327 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 2, should be 1: In scope SELECT cosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:56.256380 [ 8442 ] {fc5b2040-339b-4d5d-8c7d-0ec2cd6882d9} executeQuery: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 363, line 363) (in query: SELECT count(NULL, NULL);) 2025.06.13 15:40:56.270871 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:56.352117 [ 8442 ] {2d22ef48-c51a-49c8-b435-c3d623b847eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 2, should be 1: In scope SELECT countDigits(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 364, line 364) (in query: SELECT countDigits(NULL, NULL);) 2025.06.13 15:40:56.360239 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 2, should be 1: In scope SELECT countDigits(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:56.425662 [ 8442 ] {7082befb-0ee0-44de-9f51-c0beeb241564} executeQuery: Code: 43. DB::Exception: First argument for function countEqual must be an array. Actual Nullable(Nothing): In scope SELECT countEqual(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 365, line 365) (in query: SELECT countEqual(NULL, NULL);) 2025.06.13 15:40:56.459492 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function countEqual must be an array. Actual Nullable(Nothing): In scope SELECT countEqual(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:40:56.669365 [ 3821 ] {5834fe33-3f31-4aad-9227-969fce6caa89} executeQuery: Code: 1. DB::Exception: Recursive lambda x -> (lambda(1) + x) AS lambda. In scope x -> (lambda(1) + x) AS lambda. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56932) (comment: 02388_analyzer_recursive_lambda.sql) (query 2, line 3) (in query: WITH x -> plus(lambda(1), x) AS lambda SELECT lambda(1048576);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2615: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4292a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2d013 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc42299 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2d013 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:40:56.682230 [ 3821 ] {} TCPHandler: Code: 1. DB::Exception: Recursive lambda x -> (lambda(1) + x) AS lambda. In scope x -> (lambda(1) + x) AS lambda. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2615: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4292a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2d013 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc42299 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2d013 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:40:56.848302 [ 3821 ] {dcafa8c4-f03e-423f-abd0-ea79c492176f} executeQuery: Code: 1. DB::Exception: Recursive lambda x -> plus(lambda(1), x, 2) AS lambda. In scope x -> plus(lambda(1), x, 2) AS lambda. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56932) (comment: 02388_analyzer_recursive_lambda.sql) (query 3, line 5) (in query: WITH lambda(lambda(plus(x, x, -1)), tuple(x), x + 2147483646) AS lambda, x -> plus(lambda(1), x, 2) AS lambda SELECT 1048576, lambda(1048576);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2615: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4292a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2d013 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc42299 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2d013 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:40:56.855691 [ 3821 ] {} TCPHandler: Code: 1. DB::Exception: Recursive lambda x -> plus(lambda(1), x, 2) AS lambda. In scope x -> plus(lambda(1), x, 2) AS lambda. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2615: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc4292a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2d013 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc42299 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2d013 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:40:57.969027 [ 3931 ] {bde9ecb5-e5ed-4acd-bea8-b6c7286ea039} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1295, line 1297) (in query: SELECT synonyms(NULL, NULL);) 2025.06.13 15:40:57.976350 [ 3931 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:40:58.067010 [ 3931 ] {d4b89b12-693b-4f74-94e8-3a15cb42bfb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 2, should be 1: In scope SELECT tan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1296, line 1298) (in query: SELECT tan(NULL, NULL);) 2025.06.13 15:40:58.084676 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 2, should be 1: In scope SELECT tan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:58.163516 [ 3931 ] {518e7331-87b1-4e9c-9de8-7d7d76c52b51} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 2, should be 1: In scope SELECT tanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1297, line 1299) (in query: SELECT tanh(NULL, NULL);) 2025.06.13 15:40:58.171000 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 2, should be 1: In scope SELECT tanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:58.244963 [ 3931 ] {aff0aa30-6067-43d4-9d7c-9c17c8ff07e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 2, should be 0: In scope SELECT tcpPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1298, line 1300) (in query: SELECT tcpPort(NULL, NULL);) 2025.06.13 15:40:58.258850 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 2, should be 0: In scope SELECT tcpPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:58.351280 [ 3931 ] {79ee5acf-9884-4a01-b51f-990fee7b1c53} executeQuery: Code: 70. DB::Exception: Cannot convert NULL to a non-nullable type: In scope SELECT test_function(NULL, NULL). (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1299, line 1301) (in query: SELECT test_function(NULL, NULL);) 2025.06.13 15:40:58.366051 [ 3931 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert NULL to a non-nullable type: In scope SELECT test_function(NULL, NULL). (CANNOT_CONVERT_TYPE) 2025.06.13 15:40:58.495882 [ 3931 ] {32fbbbf5-c27a-418c-9516-49493024b85c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 2, should be 1: In scope SELECT tgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1300, line 1302) (in query: SELECT tgamma(NULL, NULL);) 2025.06.13 15:40:58.534270 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 2, should be 1: In scope SELECT tgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:58.983718 [ 3931 ] {94c9b0c8-250d-4920-8ae2-69752654f274} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 2, should be 0: In scope SELECT tid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1303, line 1305) (in query: SELECT tid(NULL, NULL);) 2025.06.13 15:40:59.001044 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 2, should be 0: In scope SELECT tid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:59.283898 [ 8442 ] {ebfd3dda-f14c-4edb-b87e-5d90520b5bfa} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT curdate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 379, line 379) (in query: SELECT curdate(NULL, NULL);) 2025.06.13 15:40:59.293559 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT curdate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:59.356982 [ 8442 ] {267744a2-fa76-48da-9b44-e2450578eaf3} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT currentDatabase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 380, line 380) (in query: SELECT currentDatabase(NULL, NULL);) 2025.06.13 15:40:59.368633 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT currentDatabase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:59.470453 [ 8442 ] {46533da7-40fa-4a2e-a050-78b1315b65ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 2, should be 0: In scope SELECT currentProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 381, line 381) (in query: SELECT currentProfiles(NULL, NULL);) 2025.06.13 15:40:59.480961 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 2, should be 0: In scope SELECT currentProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:59.569669 [ 8442 ] {71963967-e57c-484f-833a-930bd9c1822b} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 2, should be 0: In scope SELECT currentQueryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 382, line 382) (in query: SELECT currentQueryID(NULL, NULL);) 2025.06.13 15:40:59.583400 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 2, should be 0: In scope SELECT currentQueryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:59.596724 [ 3931 ] {4b052088-40b2-4e33-a9ad-ad803761f846} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1307, line 1309) (in query: SELECT timeZone(NULL, NULL);) 2025.06.13 15:40:59.611576 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:59.687856 [ 8442 ] {daa07ebf-d6b9-4ec8-958b-6bbc964fa32f} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 2, should be 0: In scope SELECT currentRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 383, line 383) (in query: SELECT currentRoles(NULL, NULL);) 2025.06.13 15:40:59.705085 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 2, should be 0: In scope SELECT currentRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:59.739893 [ 3931 ] {9f2d298b-8b64-465f-b27a-984e643da79e} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timeZoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1308, line 1310) (in query: SELECT timeZoneOf(NULL, NULL);) 2025.06.13 15:40:59.749168 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timeZoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:59.757894 [ 8442 ] {5c8209f6-2e86-48bd-b75f-79976f9a8d38} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT currentSchemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 384, line 384) (in query: SELECT currentSchemas(NULL, NULL);) 2025.06.13 15:40:59.770520 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT currentSchemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:59.869223 [ 8442 ] {868c2376-9178-454b-9ba1-6a836f46bc02} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT currentUser(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 385, line 385) (in query: SELECT currentUser(NULL, NULL);) 2025.06.13 15:40:59.876650 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT currentUser(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:40:59.955233 [ 8442 ] {a369fcf6-3252-48d4-a05b-f35ab02c88cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT current_database(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 386, line 386) (in query: SELECT current_database(NULL, NULL);) 2025.06.13 15:40:59.967998 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT current_database(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:00.041938 [ 8442 ] {cde6b8c4-b5d9-4b8d-a32b-58b9ca329233} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT current_date(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 387, line 387) (in query: SELECT current_date(NULL, NULL);) 2025.06.13 15:41:00.145351 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT current_date(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:00.244050 [ 8442 ] {796b9aa0-1105-40dd-a217-5549c6c6c7cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 2, should be 0: In scope SELECT current_query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 388, line 388) (in query: SELECT current_query_id(NULL, NULL);) 2025.06.13 15:41:00.255279 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 2, should be 0: In scope SELECT current_query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:00.399084 [ 8442 ] {b9d5c396-93b8-4d94-8f3d-22a2cbdf0625} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT current_schemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 389, line 389) (in query: SELECT current_schemas(NULL, NULL);) 2025.06.13 15:41:00.454917 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT current_schemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:00.534343 [ 8442 ] {5734e605-c994-49bc-a54f-e643ab66884f} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 390, line 390) (in query: SELECT current_timestamp(NULL, NULL);) 2025.06.13 15:41:00.574820 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:00.663638 [ 8442 ] {9ba0dd7b-cbdd-4307-8121-f5cd87550faf} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT current_user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 391, line 391) (in query: SELECT current_user(NULL, NULL);) 2025.06.13 15:41:00.670929 [ 8101 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:41:00.678039 [ 8101 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:41:00.686321 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT current_user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:00.687315 [ 9644 ] {1cc2a0c8-bead-4e07-8054-06e189a75d0a} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 : While executing Remote: While executing RecursiveCTESource. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56948) (comment: 03154_recursive_cte_distributed.sql) (query 9, line 28) (in query: WITH RECURSIVE search_tree AS ( SELECT id, parent_id, [parent_id] AS path, toUInt64(0) AS depth FROM remote('127.0.0.1', currentDatabase(), test_table) UNION ALL SELECT t.id, t.parent_id, arrayConcat(path, [t.id]) as path, depth + 1 FROM remote('127.0.0.1', currentDatabase(), test_table) t, search_tree st WHERE t.parent_id = st.id) SELECT * FROM search_tree ORDER BY depth, id, parent_id;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:41:00.717352 [ 3931 ] {6d4866be-e722-45e3-a40f-d05e6d379383} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1314, line 1316) (in query: SELECT timezone(NULL, NULL);) 2025.06.13 15:41:00.741258 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:00.761891 [ 9644 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 : While executing Remote: While executing RecursiveCTESource. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:134: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003222beeb 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x000000003222bc62 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:41:00.805917 [ 3931 ] {881c7386-245c-4f29-8303-79fa93d1b9c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timezoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1315, line 1317) (in query: SELECT timezoneOf(NULL, NULL);) 2025.06.13 15:41:00.805924 [ 8442 ] {2ae4cd54-aa62-4f2f-9028-5629657a36fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 2, should be 1: In scope SELECT cutFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 392, line 392) (in query: SELECT cutFragment(NULL, NULL);) 2025.06.13 15:41:00.821116 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timezoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:00.821596 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 2, should be 1: In scope SELECT cutFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:00.934086 [ 8442 ] {0e7cae06-38df-4a83-b71c-70d6a92ff2f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 2, should be 3: In scope SELECT cutIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 393, line 393) (in query: SELECT cutIPv6(NULL, NULL);) 2025.06.13 15:41:00.952246 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 2, should be 3: In scope SELECT cutIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:01.095574 [ 8442 ] {ce320eeb-2def-42b0-9a9a-71410e8ebc91} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 2, should be 1: In scope SELECT cutQueryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 394, line 394) (in query: SELECT cutQueryString(NULL, NULL);) 2025.06.13 15:41:01.119042 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 2, should be 1: In scope SELECT cutQueryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:01.220541 [ 6234 ] {b770d3eb-6069-4478-bfa4-daa778e6ca70} executeQuery: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([toUInt64(1)], [1], 18446744073709551615). (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57112) (comment: 01698_map_populate_overflow.sql) (query 2, line 2) (in query: SELECT mapPopulateSeries([toUInt64(1)], [1], 0xFFFFFFFFFFFFFFFF);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x00000000236fc1e6 6. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x00000000236fb1cc 7. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002364f1d6 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:41:01.235471 [ 6234 ] {} TCPHandler: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([toUInt64(1)], [1], 18446744073709551615). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x00000000236fc1e6 6. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x00000000236fb1cc 7. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002364f1d6 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:41:01.291550 [ 8442 ] {a7e5980b-8903-4fab-afb8-6274040bc438} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 395, line 395) (in query: SELECT cutQueryStringAndFragment(NULL, NULL);) 2025.06.13 15:41:01.298874 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:01.398851 [ 8442 ] {1f35cd34-8f2f-49a2-a31b-d245363b167d} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 396, line 396) (in query: SELECT cutToFirstSignificantSubdomain(NULL, NULL);) 2025.06.13 15:41:01.412278 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:01.449889 [ 8099 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:01.673487 [ 3931 ] {e1934fe1-20f6-4b2c-8b90-3f981d64c42c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 2, should be 1: In scope SELECT toBool(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1320, line 1322) (in query: SELECT toBool(NULL, NULL);) 2025.06.13 15:41:01.756350 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 2, should be 1: In scope SELECT toBool(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:01.820313 [ 3931 ] {a827a710-98c6-4b4d-bce9-d4fab930a635} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 2, should be 1: In scope SELECT toColumnTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1321, line 1323) (in query: SELECT toColumnTypeName(NULL, NULL);) 2025.06.13 15:41:01.856293 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 2, should be 1: In scope SELECT toColumnTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:02.178379 [ 8442 ] {534fc6bf-6e7e-4ed6-be09-900dadd259dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 401, line 401) (in query: SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL);) 2025.06.13 15:41:02.185860 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:02.308224 [ 8442 ] {c9c6049f-b113-4e17-a539-b913eb14a44c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 402, line 402) (in query: SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL);) 2025.06.13 15:41:02.376580 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:02.473832 [ 8442 ] {304057d1-af6f-49c1-8071-ae01664a84ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 403, line 403) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL);) 2025.06.13 15:41:02.474329 [ 3931 ] {dcc4e2f0-e6e9-4cd1-b6dc-f9e90960d620} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date32. Actual Nullable(Nothing): In scope SELECT toDate32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1324, line 1326) (in query: SELECT toDate32OrDefault(NULL, NULL);) 2025.06.13 15:41:02.479312 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:02.484576 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date32. Actual Nullable(Nothing): In scope SELECT toDate32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:02.824329 [ 8442 ] {f8857f1d-1fc1-46dc-b540-98e0831f137d} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 2, should be 1: In scope SELECT cutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 405, line 405) (in query: SELECT cutWWW(NULL, NULL);) 2025.06.13 15:41:02.832695 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 2, should be 1: In scope SELECT cutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:03.008641 [ 3931 ] {d54d5c7d-ba15-4dc1-8fbd-952313f10c5b} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date. Actual Nullable(Nothing): In scope SELECT toDateOrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1327, line 1329) (in query: SELECT toDateOrDefault(NULL, NULL);) 2025.06.13 15:41:03.019714 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date. Actual Nullable(Nothing): In scope SELECT toDateOrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:03.595156 [ 8442 ] {2d90f5de-a812-4d97-b079-ae82f1aa54d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 409, line 409) (in query: SELECT dateTime64ToSnowflake(NULL, NULL);) 2025.06.13 15:41:03.632497 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:03.878361 [ 8442 ] {7eb7048a-2c5c-4088-a3e7-658034e170d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 411, line 411) (in query: SELECT dateTimeToSnowflake(NULL, NULL);) 2025.06.13 15:41:03.889284 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:04.131509 [ 3931 ] {b3412005-291a-4f68-a146-ab58e43507f2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1333, line 1335) (in query: SELECT toDateTime64OrDefault(NULL, NULL);) 2025.06.13 15:41:04.160788 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:04.498327 [ 3039 ] {} test_1.data_02340_rep (9dafebe8-ca48-4a31-8757-85aefa0e0059): 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000311081b3 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000030634b35 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:04.578812 [ 3931 ] {88d0d2a6-aa26-4390-9341-8133014db378} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1336, line 1338) (in query: SELECT toDateTimeOrDefault(NULL, NULL);) 2025.06.13 15:41:04.595946 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:04.714691 [ 8442 ] {2c4b5c22-7867-48a3-80e7-d62ad5aeb2f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 416, line 416) (in query: SELECT decodeHTMLComponent(NULL, NULL);) 2025.06.13 15:41:04.731682 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:04.840553 [ 8442 ] {610e9762-b417-4e5e-a831-f6b9c59f9274} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 417, line 417) (in query: SELECT decodeURLComponent(NULL, NULL);) 2025.06.13 15:41:04.852726 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:04.955774 [ 8442 ] {0fd3a17b-d195-4f28-bde0-dfef31a6f8d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 418, line 418) (in query: SELECT decodeURLFormComponent(NULL, NULL);) 2025.06.13 15:41:04.963751 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:05.071148 [ 8442 ] {dee0c058-6848-4a0c-a4a1-94fc6c368ff4} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 419, line 419) (in query: SELECT decodeXMLComponent(NULL, NULL);) 2025.06.13 15:41:05.075621 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:05.347872 [ 8442 ] {2f362774-ebc2-47f9-8c8f-8f7f9baf4af2} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 2, should be 0: In scope SELECT defaultProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 421, line 421) (in query: SELECT defaultProfiles(NULL, NULL);) 2025.06.13 15:41:05.366086 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 2, should be 0: In scope SELECT defaultProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:05.474882 [ 8442 ] {461ddfcf-8283-48c2-81b4-d4e2ab6199e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 2, should be 0: In scope SELECT defaultRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 422, line 422) (in query: SELECT defaultRoles(NULL, NULL);) 2025.06.13 15:41:05.484488 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 2, should be 0: In scope SELECT defaultRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:05.504248 [ 3075 ] {} test_1.data_02340_rep (9dafebe8-ca48-4a31-8757-85aefa0e0059): 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000311081b3 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000030634b35 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:05.581360 [ 8442 ] {b972e238-f07e-4bc4-9fc6-b426b01bf608} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 423, line 423) (in query: SELECT defaultValueOfArgumentType(NULL, NULL);) 2025.06.13 15:41:05.591274 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:05.705852 [ 8442 ] {4e33e0ea-7e89-49a1-beeb-242747bf3360} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 424, line 424) (in query: SELECT defaultValueOfTypeName(NULL, NULL);) 2025.06.13 15:41:05.717405 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:05.798030 [ 8442 ] {61b0dbcf-bf1b-4554-ab2f-e21d23abef0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 2, should be 1: In scope SELECT degrees(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 425, line 425) (in query: SELECT degrees(NULL, NULL);) 2025.06.13 15:41:05.811131 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 2, should be 1: In scope SELECT degrees(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:05.924229 [ 3931 ] {792ed09a-e3b2-4f87-b6b5-1366af3691dc} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1344, line 1346) (in query: SELECT toDecimal128OrDefault(NULL, NULL);) 2025.06.13 15:41:05.941756 [ 8442 ] {15daf340-d7fd-4f14-bb4c-20d3710a05e7} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 426, line 426) (in query: SELECT deltaSum(NULL, NULL);) 2025.06.13 15:41:06.033018 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:06.041585 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:06.140054 [ 8442 ] {a512bf36-98b5-42c6-99ef-44f09d2b674b} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 427, line 427) (in query: SELECT deltaSumTimestamp(NULL, NULL);) 2025.06.13 15:41:06.156772 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:06.241564 [ 8442 ] {5a2e09a2-9cde-43bb-8977-b3cd3bf84ddf} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 2, should be 1: In scope SELECT demangle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 428, line 428) (in query: SELECT demangle(NULL, NULL);) 2025.06.13 15:41:06.251636 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 2, should be 1: In scope SELECT demangle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:06.441088 [ 8442 ] {e935cb2a-608a-4fa4-8415-d822bf6f1ad1} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 429, line 429) (in query: SELECT denseRank(NULL, NULL);) 2025.06.13 15:41:06.471523 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:41:06.510172 [ 3179 ] {} test_1.data_02340_rep (9dafebe8-ca48-4a31-8757-85aefa0e0059): 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000311081b3 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000030634b35 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:06.621248 [ 3931 ] {2f046a9f-ec3f-4d45-ad6e-0fc00dc039b7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1348, line 1350) (in query: SELECT toDecimal256OrDefault(NULL, NULL);) 2025.06.13 15:41:06.649148 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:06.760087 [ 8442 ] {9a71a88f-4ddd-4397-a636-ef6a399b308b} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 430, line 430) (in query: SELECT dense_rank(NULL, NULL);) 2025.06.13 15:41:06.775857 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:41:06.931367 [ 8442 ] {2faec04e-36ba-453f-b938-40d87007e2ff} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 431, line 431) (in query: SELECT detectCharset(NULL, NULL);) 2025.06.13 15:41:06.952788 [ 4171 ] {5649ffa3-3ce1-4fc8-959d-1140d4fbb461} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:59602). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59602) (comment: 02360_send_logs_level_colors.sh) (query 1, line 1) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316ba300 7. ./build_docker/./src/Server/TCPHandler.cpp:727: DB::TCPHandler::runImpl() @ 0x00000000316a4559 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:41:06.956796 [ 8442 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:41:06.965894 [ 4171 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:59602). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316ba300 7. ./build_docker/./src/Server/TCPHandler.cpp:727: DB::TCPHandler::runImpl() @ 0x00000000316a4559 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:41:07.085462 [ 8442 ] {aff7ead6-ef9d-4b03-977c-811d4ac87435} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 432, line 432) (in query: SELECT detectLanguage(NULL, NULL);) 2025.06.13 15:41:07.096461 [ 8442 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:41:07.176731 [ 8442 ] {2ef8c48c-fdfa-4162-8635-1f398fc03bd5} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 433, line 433) (in query: SELECT detectLanguageMixed(NULL, NULL);) 2025.06.13 15:41:07.196934 [ 8442 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:41:07.324237 [ 8442 ] {e411713a-9c0e-45ec-9705-588e547c7fbc} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 434, line 434) (in query: SELECT detectLanguageUnknown(NULL, NULL);) 2025.06.13 15:41:07.352808 [ 8442 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:41:07.353009 [ 3931 ] {0622986f-4cbd-48ef-af8c-92defdefecc7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1352, line 1354) (in query: SELECT toDecimal32OrDefault(NULL, NULL);) 2025.06.13 15:41:07.364155 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:07.469341 [ 8442 ] {505a5e06-7066-4e23-b76e-6bdebd240f7e} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 435, line 435) (in query: SELECT detectProgrammingLanguage(NULL, NULL);) 2025.06.13 15:41:07.495425 [ 8442 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:41:07.516140 [ 3232 ] {} test_1.data_02340_rep (9dafebe8-ca48-4a31-8757-85aefa0e0059): 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:638: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000311081b3 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000030634b35 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:07.667434 [ 8442 ] {f58f48ae-289a-4df0-ae04-eb4e4761df31} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 436, line 436) (in query: SELECT detectTonality(NULL, NULL);) 2025.06.13 15:41:07.707144 [ 8442 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:41:07.836141 [ 8442 ] {344930ad-d3dd-4db8-ab00-5e11b4182446} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 437, line 437) (in query: SELECT dictGet(NULL, NULL);) 2025.06.13 15:41:07.857398 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:07.988418 [ 8442 ] {0ec88880-7a2e-47b1-b82c-d1114d635c3e} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 438, line 438) (in query: SELECT dictGetAll(NULL, NULL);) 2025.06.13 15:41:08.035455 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:08.175388 [ 3931 ] {98431a1b-a013-4f3e-9973-cff897888864} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1356, line 1358) (in query: SELECT toDecimal64OrDefault(NULL, NULL);) 2025.06.13 15:41:08.183608 [ 8442 ] {99fb8245-da33-4f6a-8c72-6e186f046d36} executeQuery: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetChildren(NULL, NULL). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 439, line 439) (in query: SELECT dictGetChildren(NULL, NULL);) 2025.06.13 15:41:08.192792 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:08.216726 [ 8442 ] {} TCPHandler: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetChildren(NULL, NULL). (UNSUPPORTED_METHOD) 2025.06.13 15:41:08.454374 [ 8442 ] {08608252-ec22-4815-a88a-e8aeb5db410d} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDate doesn't match: the function requires more arguments: In scope SELECT dictGetDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 440, line 440) (in query: SELECT dictGetDate(NULL, NULL);) 2025.06.13 15:41:08.461654 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDate doesn't match: the function requires more arguments: In scope SELECT dictGetDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:08.540286 [ 8430 ] {2b6e2b8f-09b3-4705-9756-5e393631e9f8} executeQuery: Code: 184. DB::Exception: Aggregate function sum(marks) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59536) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (query 5, line 9) (in query: SELECT ignore(toFixedString('Lambda as function parameter', 28), toNullable(28), ignore(8)), sum(marks) FROM system.parts WHERE database = currentDatabase() GROUP BY GROUPING SETS ((2)) FORMAT Null settings optimize_injective_functions_in_group_by=1, optimize_group_by_function_keys=1, group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04442f 5. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f4e4 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f275 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f275 8. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000002cc9f757 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc97a50 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:41:08.558230 [ 8430 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function sum(marks) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04442f 5. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f4e4 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f275 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f275 8. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000002cc9f757 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc97a50 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:41:08.578494 [ 8442 ] {9812bf86-2e3d-45bf-929d-82181744125d} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 441, line 441) (in query: SELECT dictGetDateOrDefault(NULL, NULL);) 2025.06.13 15:41:08.589282 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:08.740948 [ 8442 ] {7d9b749b-7c8c-491e-ab5f-f9053e403abf} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateTime doesn't match: the function requires more arguments: In scope SELECT dictGetDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 442, line 442) (in query: SELECT dictGetDateTime(NULL, NULL);) 2025.06.13 15:41:08.763604 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateTime doesn't match: the function requires more arguments: In scope SELECT dictGetDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:08.957931 [ 8442 ] {59697e60-b4a5-4536-8fe7-85244af5eb63} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateTimeOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateTimeOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 443, line 443) (in query: SELECT dictGetDateTimeOrDefault(NULL, NULL);) 2025.06.13 15:41:08.972573 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateTimeOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateTimeOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:09.095106 [ 8442 ] {249bbd24-189d-4e39-ba42-c4bca54ae1f2} executeQuery: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 444, line 444) (in query: SELECT dictGetDescendants(NULL, NULL);) 2025.06.13 15:41:09.175233 [ 8442 ] {} TCPHandler: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL). (UNSUPPORTED_METHOD) 2025.06.13 15:41:09.405742 [ 8442 ] {e4c493ca-e5c9-4135-8f3b-e3f57b7e68ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 445, line 445) (in query: SELECT dictGetFloat32(NULL, NULL);) 2025.06.13 15:41:09.455265 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:09.538343 [ 3931 ] {2b9ad713-def1-4bee-a04b-95eba126095c} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float32. Actual Nullable(Nothing): In scope SELECT toFloat32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1362, line 1364) (in query: SELECT toFloat32OrDefault(NULL, NULL);) 2025.06.13 15:41:09.549402 [ 8442 ] {f8d7464c-1268-44e1-a1e3-b95ed8a31c76} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 446, line 446) (in query: SELECT dictGetFloat32OrDefault(NULL, NULL);) 2025.06.13 15:41:09.549977 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float32. Actual Nullable(Nothing): In scope SELECT toFloat32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:09.567146 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:09.676119 [ 8442 ] {ac36c667-1014-43ed-8ad5-ee3fe85dffb8} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 447, line 447) (in query: SELECT dictGetFloat64(NULL, NULL);) 2025.06.13 15:41:09.690933 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:09.923300 [ 8442 ] {94166a48-8266-44ea-bdd3-30dfeb057c2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 448, line 448) (in query: SELECT dictGetFloat64OrDefault(NULL, NULL);) 2025.06.13 15:41:09.964042 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:10.422727 [ 8442 ] {2fed5e69-610c-4dee-916e-667d57a90ac7} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 450, line 450) (in query: SELECT dictGetIPv4(NULL, NULL);) 2025.06.13 15:41:10.450864 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:10.527524 [ 3931 ] {af044fd3-16c8-4aef-97fd-16d70e9372ec} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float64. Actual Nullable(Nothing): In scope SELECT toFloat64OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1366, line 1368) (in query: SELECT toFloat64OrDefault(NULL, NULL);) 2025.06.13 15:41:10.556850 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float64. Actual Nullable(Nothing): In scope SELECT toFloat64OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:10.564969 [ 8442 ] {c8e30679-7d60-4f16-b246-1a542fc35209} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 451, line 451) (in query: SELECT dictGetIPv4OrDefault(NULL, NULL);) 2025.06.13 15:41:10.599336 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:10.677519 [ 8442 ] {ebb9daef-6d97-47e8-9cce-0f9d5324a425} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 452, line 452) (in query: SELECT dictGetIPv6(NULL, NULL);) 2025.06.13 15:41:10.685874 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:10.802969 [ 8442 ] {e9082ab7-fcec-441e-9217-12d36381d505} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 453, line 453) (in query: SELECT dictGetIPv6OrDefault(NULL, NULL);) 2025.06.13 15:41:10.812255 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:10.936113 [ 8442 ] {90a6f2c6-08d6-4b49-87a7-991bd5cdc3f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 454, line 454) (in query: SELECT dictGetInt16(NULL, NULL);) 2025.06.13 15:41:10.965354 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:11.053225 [ 8442 ] {b8b42cab-f555-417c-9f4e-48b516c20b8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 455, line 455) (in query: SELECT dictGetInt16OrDefault(NULL, NULL);) 2025.06.13 15:41:11.080492 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:11.226511 [ 8442 ] {7fdd4d15-4077-47a5-9508-8806ce5a01dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 456, line 456) (in query: SELECT dictGetInt32(NULL, NULL);) 2025.06.13 15:41:11.247608 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:11.381109 [ 8442 ] {5620a7d9-e77d-4fc8-a693-2a8b35b88703} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 457, line 457) (in query: SELECT dictGetInt32OrDefault(NULL, NULL);) 2025.06.13 15:41:11.422898 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:11.471552 [ 3931 ] {baae099c-2509-4e24-9bf7-47531094de23} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv4. Actual Nullable(Nothing): In scope SELECT toIPv4OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1371, line 1373) (in query: SELECT toIPv4OrDefault(NULL, NULL);) 2025.06.13 15:41:11.476533 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv4. Actual Nullable(Nothing): In scope SELECT toIPv4OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:11.544502 [ 8442 ] {abbb6a1b-9d55-4185-9efd-55098eccbc0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 458, line 458) (in query: SELECT dictGetInt64(NULL, NULL);) 2025.06.13 15:41:11.545172 [ 5110 ] {92af0e79-5765-41c5-bc7c-f3339c944911} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_7/x1/replicas/r1). (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58470) (comment: 02021_create_database_with_comment.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_7;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000030587a41 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6938: DB::StorageReplicatedMergeTree::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030695dbf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:41:11.557377 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:11.575343 [ 5110 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_7/x1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000030587a41 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6938: DB::StorageReplicatedMergeTree::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030695dbf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:41:11.662044 [ 8442 ] {dd9142c0-9c9c-49a9-826a-1374d992a18c} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 459, line 459) (in query: SELECT dictGetInt64OrDefault(NULL, NULL);) 2025.06.13 15:41:11.672749 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:11.745526 [ 8442 ] {9dc1e25e-3e64-42fe-9ccb-3e3a9958f286} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 460, line 460) (in query: SELECT dictGetInt8(NULL, NULL);) 2025.06.13 15:41:11.757230 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:11.951814 [ 8442 ] {7e2275c4-e45c-4822-b987-4851364bb162} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 461, line 461) (in query: SELECT dictGetInt8OrDefault(NULL, NULL);) 2025.06.13 15:41:12.021157 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:12.101797 [ 4171 ] {d2164ddc-e0c3-4991-a37b-5413b4ae1485} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59660) (comment: 01825_type_json_bools.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:41:12.178666 [ 4171 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:41:12.203319 [ 8442 ] {cd4d6906-919f-40c5-879f-472503b83561} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 462, line 462) (in query: SELECT dictGetOrDefault(NULL, NULL);) 2025.06.13 15:41:12.236696 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:12.311245 [ 3931 ] {46d0da6e-f07e-4318-8359-4243c0bf1aa4} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv6. Actual Nullable(Nothing): In scope SELECT toIPv6OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1375, line 1377) (in query: SELECT toIPv6OrDefault(NULL, NULL);) 2025.06.13 15:41:12.335048 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv6. Actual Nullable(Nothing): In scope SELECT toIPv6OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:12.370236 [ 8442 ] {3e01d2ae-89d8-4d0f-80cf-acdc9960ffc2} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 463, line 463) (in query: SELECT dictGetOrNull(NULL, NULL);) 2025.06.13 15:41:12.414631 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:12.589562 [ 8442 ] {9f02ea6d-1d2d-489e-b6ef-53f1f0dc7022} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetString doesn't match: the function requires more arguments: In scope SELECT dictGetString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 464, line 464) (in query: SELECT dictGetString(NULL, NULL);) 2025.06.13 15:41:12.602906 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetString doesn't match: the function requires more arguments: In scope SELECT dictGetString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:12.759278 [ 8442 ] {cd84ae20-ea07-4564-a3b8-0f459d47d72e} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetStringOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetStringOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 465, line 465) (in query: SELECT dictGetStringOrDefault(NULL, NULL);) 2025.06.13 15:41:12.775089 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetStringOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetStringOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:12.957460 [ 8442 ] {3ec3bdfc-a5dd-42c0-a869-79453e1d7675} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 466, line 466) (in query: SELECT dictGetUInt16(NULL, NULL);) 2025.06.13 15:41:12.964975 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:13.114372 [ 8442 ] {fe836422-7b33-43c7-8ebd-ed73e22b46a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 467, line 467) (in query: SELECT dictGetUInt16OrDefault(NULL, NULL);) 2025.06.13 15:41:13.155785 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:13.311586 [ 8442 ] {5503be14-8fee-4368-b444-96146997e9de} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 468, line 468) (in query: SELECT dictGetUInt32(NULL, NULL);) 2025.06.13 15:41:13.348895 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:13.492337 [ 8442 ] {5f4dd35e-e9c2-4696-8017-3495bb5d70c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 469, line 469) (in query: SELECT dictGetUInt32OrDefault(NULL, NULL);) 2025.06.13 15:41:13.549173 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:13.639119 [ 3931 ] {b0dd0306-173a-482a-8718-e288f5643b43} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int128. Actual Nullable(Nothing): In scope SELECT toInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1381, line 1383) (in query: SELECT toInt128OrDefault(NULL, NULL);) 2025.06.13 15:41:13.658041 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int128. Actual Nullable(Nothing): In scope SELECT toInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:13.708923 [ 8442 ] {b0dca467-0ec2-4d51-93fa-27ffdb03d3e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 470, line 470) (in query: SELECT dictGetUInt64(NULL, NULL);) 2025.06.13 15:41:13.744254 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:13.834097 [ 8442 ] {0f600f21-2ec0-4144-9b41-8e0ea0f29f35} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 471, line 471) (in query: SELECT dictGetUInt64OrDefault(NULL, NULL);) 2025.06.13 15:41:13.848518 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:13.985019 [ 8442 ] {e4b3ad2d-304d-40b9-84b3-1310d3f8d20f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 472, line 472) (in query: SELECT dictGetUInt8(NULL, NULL);) 2025.06.13 15:41:14.027230 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:14.210641 [ 8442 ] {43649236-49af-4d2b-a902-8ceb830dc8d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 473, line 473) (in query: SELECT dictGetUInt8OrDefault(NULL, NULL);) 2025.06.13 15:41:14.245752 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:14.336748 [ 8442 ] {6399e3fa-33df-4c7f-a78d-eddeddd36492} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUUID doesn't match: the function requires more arguments: In scope SELECT dictGetUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 474, line 474) (in query: SELECT dictGetUUID(NULL, NULL);) 2025.06.13 15:41:14.351886 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUUID doesn't match: the function requires more arguments: In scope SELECT dictGetUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:14.368176 [ 3931 ] {ff5269a7-6733-4bd7-80da-ff9ad7af4447} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int16. Actual Nullable(Nothing): In scope SELECT toInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1385, line 1387) (in query: SELECT toInt16OrDefault(NULL, NULL);) 2025.06.13 15:41:14.380825 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int16. Actual Nullable(Nothing): In scope SELECT toInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:14.437891 [ 8442 ] {825cfa9c-1092-4eba-8480-a42734f32750} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUUIDOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUUIDOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 475, line 475) (in query: SELECT dictGetUUIDOrDefault(NULL, NULL);) 2025.06.13 15:41:14.443558 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUUIDOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUUIDOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:14.729764 [ 8442 ] {5a3b3286-7a57-4537-8238-4fc92e04ba42} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 2, should be 3: In scope SELECT dictIsIn(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 477, line 477) (in query: SELECT dictIsIn(NULL, NULL);) 2025.06.13 15:41:14.744857 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 2, should be 3: In scope SELECT dictIsIn(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:14.792386 [ 8442 ] {e5bef087-fa45-4196-8e0d-dbba98be7675} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 2, should be 0: In scope SELECT displayName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 478, line 478) (in query: SELECT displayName(NULL, NULL);) 2025.06.13 15:41:14.800529 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 2, should be 0: In scope SELECT displayName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:14.816993 [ 3931 ] {aae20414-7844-4f46-a714-9f5833557120} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int256. Actual Nullable(Nothing): In scope SELECT toInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1389, line 1391) (in query: SELECT toInt256OrDefault(NULL, NULL);) 2025.06.13 15:41:14.845200 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int256. Actual Nullable(Nothing): In scope SELECT toInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:15.249367 [ 3931 ] {ae60a192-e83d-40ec-a7e2-b35f9d8286ea} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int32. Actual Nullable(Nothing): In scope SELECT toInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1393, line 1395) (in query: SELECT toInt32OrDefault(NULL, NULL);) 2025.06.13 15:41:15.258224 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int32. Actual Nullable(Nothing): In scope SELECT toInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:15.481691 [ 8442 ] {d5a91500-f53f-4798-bd53-c0bb81ada15e} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT distanceLp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 483, line 483) (in query: SELECT distanceLp(NULL, NULL);) 2025.06.13 15:41:15.497470 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT distanceLp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:15.817384 [ 3931 ] {08fc8138-5b26-4fab-9ac2-6e92df8d29a2} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int64. Actual Nullable(Nothing): In scope SELECT toInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1397, line 1399) (in query: SELECT toInt64OrDefault(NULL, NULL);) 2025.06.13 15:41:15.833296 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int64. Actual Nullable(Nothing): In scope SELECT toInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:16.477452 [ 8442 ] {7899001c-3956-4103-9caa-e9ac2df88aaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 2, should be 1: In scope SELECT domain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 489, line 489) (in query: SELECT domain(NULL, NULL);) 2025.06.13 15:41:16.478147 [ 3931 ] {4edda1af-b8cd-4755-9845-8d2177b8ca1c} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int8. Actual Nullable(Nothing): In scope SELECT toInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1401, line 1403) (in query: SELECT toInt8OrDefault(NULL, NULL);) 2025.06.13 15:41:16.505221 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 2, should be 1: In scope SELECT domain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:16.513831 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int8. Actual Nullable(Nothing): In scope SELECT toInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:16.634954 [ 8442 ] {6f350d7b-a810-42d5-8c6b-af231f4bfbdf} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 2, should be 1: In scope SELECT domainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 490, line 490) (in query: SELECT domainRFC(NULL, NULL);) 2025.06.13 15:41:16.654952 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 2, should be 1: In scope SELECT domainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:16.768128 [ 8442 ] {ce11fae9-316e-4314-b851-eb017f0e5b87} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 491, line 491) (in query: SELECT domainWithoutWWW(NULL, NULL);) 2025.06.13 15:41:16.798623 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:16.973504 [ 8442 ] {2e064228-ebd3-4dbb-9e80-eeefe1aa9115} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 492, line 492) (in query: SELECT domainWithoutWWWRFC(NULL, NULL);) 2025.06.13 15:41:16.979204 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:17.278544 [ 8442 ] {db5d38f9-5ebb-42c2-94f0-5f62a586ef87} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 2, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 494, line 494) (in query: SELECT dumpColumnStructure(NULL, NULL);) 2025.06.13 15:41:17.295122 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 2, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:17.433832 [ 8442 ] {15bf6697-0898-462f-9141-6af188b0431b} executeQuery: Code: 43. DB::Exception: First argument for function dynamicElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT dynamicElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 495, line 495) (in query: SELECT dynamicElement(NULL, NULL);) 2025.06.13 15:41:17.455186 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function dynamicElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT dynamicElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:17.540937 [ 8431 ] {368b2701-8311-4002-a628-4a46a176bd04} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictGet('02176_test_simple_key_dictionary', 'value', [0]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46410) (comment: 02176_dict_get_has_implicit_key_cast.sql) (query 9, line 23) (in query: SELECT dictGet('02176_test_simple_key_dictionary', 'value', [0]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b038010 6. ./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 @ 0x000000002b036ba3 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], 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) @ 0x000000002addf493 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 18. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25278e 19. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e252fc4 20. ./src/Dictionaries/IDictionary.h:165: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000028a27899 21. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f43a9f 22. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 23. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 25. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 2025.06.13 15:41:17.549899 [ 8431 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictGet('02176_test_simple_key_dictionary', 'value', [0]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b038010 6. ./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 @ 0x000000002b036ba3 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], 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) @ 0x000000002addf493 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 18. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25278e 19. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e252fc4 20. ./src/Dictionaries/IDictionary.h:165: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000028a27899 21. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f43a9f 22. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 23. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 25. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 2025.06.13 15:41:17.582877 [ 8442 ] {103151bc-965e-40ba-8e4b-7504be849c0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 2, should be 1: In scope SELECT dynamicType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 496, line 496) (in query: SELECT dynamicType(NULL, NULL);) 2025.06.13 15:41:17.589704 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 2, should be 1: In scope SELECT dynamicType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:17.652707 [ 8442 ] {c4854633-fa85-44e2-9a95-b93cc0b160fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 2, should be 0: In scope SELECT e(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 497, line 497) (in query: SELECT e(NULL, NULL);) 2025.06.13 15:41:17.662025 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 2, should be 0: In scope SELECT e(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:18.002477 [ 8442 ] {6ed322b7-eceb-44a4-ae4c-f08258343759} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 2, should be 1: In scope SELECT empty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 500, line 500) (in query: SELECT empty(NULL, NULL);) 2025.06.13 15:41:18.011516 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 2, should be 1: In scope SELECT empty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:18.066959 [ 8442 ] {01fe0ec8-0f58-4e51-8572-ae58ec1aea9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 501, line 501) (in query: SELECT emptyArrayDate(NULL, NULL);) 2025.06.13 15:41:18.076569 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:18.101924 [ 8430 ] {f1b5bb31-8e9e-4111-8f4a-3ed857dbb7ce} executeQuery: Code: 184. DB::Exception: Aggregate function count('Lambda as function parameter') AS c is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59536) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (query 15, line 49) (in query: SELECT count('Lambda as function parameter') AS c FROM (SELECT ignore(ignore('Lambda as function parameter', 28, 28, 28, 28, 28, 28), 28), materialize('Lambda as function parameter'), 28, 28, 'world', 5 FROM system.numbers WHERE ignore(materialize('Lambda as function parameter'), materialize(toLowCardinality(28)), 28, 28, 28, 28, toUInt128(28)) LIMIT 2) GROUP BY GROUPING SETS ((toLowCardinality(0)), (toLowCardinality(toNullable(28))), (1)) HAVING nullIf(c, 10) < 50 ORDER BY c ASC NULLS FIRST settings group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04442f 5. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f4e4 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f275 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f275 8. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000002cc9f757 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc97a50 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:41:18.108048 [ 8430 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function count('Lambda as function parameter') AS c is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04442f 5. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f4e4 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f275 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f275 8. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000002cc9f757 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc97a50 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:41:18.121827 [ 8442 ] {c7336d00-1385-4b55-be33-46fe2e224c1f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 502, line 502) (in query: SELECT emptyArrayDateTime(NULL, NULL);) 2025.06.13 15:41:18.128090 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:18.178009 [ 8442 ] {d942328f-0ae7-45e4-ba7d-ba9336a154e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 503, line 503) (in query: SELECT emptyArrayFloat32(NULL, NULL);) 2025.06.13 15:41:18.185641 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:18.258544 [ 8442 ] {3e97317d-74ac-490d-b2fc-215b33b0afe9} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 504, line 504) (in query: SELECT emptyArrayFloat64(NULL, NULL);) 2025.06.13 15:41:18.264372 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:18.335531 [ 8442 ] {1cea18fd-c162-4328-97ed-aa27acf94d91} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 505, line 505) (in query: SELECT emptyArrayInt16(NULL, NULL);) 2025.06.13 15:41:18.343270 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:18.378000 [ 3931 ] {e6b89b3c-1935-40f2-86de-b71ebabfa8e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 2, should be 1: In scope SELECT toJSONString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1415, line 1417) (in query: SELECT toJSONString(NULL, NULL);) 2025.06.13 15:41:18.416701 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 2, should be 1: In scope SELECT toJSONString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:18.482967 [ 8442 ] {9b5ad795-282c-4fba-89f6-79214b92734f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 506, line 506) (in query: SELECT emptyArrayInt32(NULL, NULL);) 2025.06.13 15:41:18.494248 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:18.607438 [ 8442 ] {a5b7d70c-c942-437f-bd90-df0e6ef25cde} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 507, line 507) (in query: SELECT emptyArrayInt64(NULL, NULL);) 2025.06.13 15:41:18.611846 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:18.612690 [ 8431 ] {1092d906-c1d8-4281-82ef-24baf6eaedee} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictHas('02176_test_simple_key_dictionary', [0]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46410) (comment: 02176_dict_get_has_implicit_key_cast.sql) (query 13, line 28) (in query: SELECT dictHas('02176_test_simple_key_dictionary', [0]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b038010 6. ./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 @ 0x000000002b036ba3 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], 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) @ 0x000000002addf493 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 18. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25278e 19. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e252fc4 20. ./src/Dictionaries/IDictionary.h:165: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000028a27899 21. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f582fa 22. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 23. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 25. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 2025.06.13 15:41:18.623609 [ 8431 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictHas('02176_test_simple_key_dictionary', [0]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b038010 6. ./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 @ 0x000000002b036ba3 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], 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) @ 0x000000002addf493 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 18. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25278e 19. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e252fc4 20. ./src/Dictionaries/IDictionary.h:165: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000028a27899 21. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f582fa 22. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 23. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 25. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 2025.06.13 15:41:18.746098 [ 3931 ] {8fa05f93-2c4e-4afd-8226-f1ea84cefae5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 2, should be 1: In scope SELECT toLowCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1418, line 1420) (in query: SELECT toLowCardinality(NULL, NULL);) 2025.06.13 15:41:18.750350 [ 8442 ] {1d68bc66-ead3-4d31-847b-40d30d6bb575} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 508, line 508) (in query: SELECT emptyArrayInt8(NULL, NULL);) 2025.06.13 15:41:18.761992 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 2, should be 1: In scope SELECT toLowCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:18.762340 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:18.876063 [ 8442 ] {03cb0ba6-b966-40ea-98ac-01f3fc63114e} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 2, should be 0: In scope SELECT emptyArrayString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 509, line 509) (in query: SELECT emptyArrayString(NULL, NULL);) 2025.06.13 15:41:18.886580 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 2, should be 0: In scope SELECT emptyArrayString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:18.956439 [ 8442 ] {e056e6f0-f8a4-4f05-98f8-4bb15338887d} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 2, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 510, line 510) (in query: SELECT emptyArrayToSingle(NULL, NULL);) 2025.06.13 15:41:18.966489 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 2, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:19.043592 [ 8442 ] {21501edb-1c9e-41a7-a0f3-1b251e424d68} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 511, line 511) (in query: SELECT emptyArrayUInt16(NULL, NULL);) 2025.06.13 15:41:19.055428 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:19.125648 [ 8430 ] {7462e51d-35b4-4c35-bdb6-ec5ecde051d1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Array(Nothing)) of argument of function toUInt8: while executing 'FUNCTION toUInt8(number :: 0) -> toUInt8(number) UInt8 : 1': while executing 'FUNCTION arraySplit(number Array(Array(Nothing)) -> toUInt8(number) :: 1, array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String))) :: 2) -> arraySplit(number Array(Array(Nothing)) -> toUInt8(number), array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String)))) Array(Array(Array(Array(Nothing)))) : 4'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59536) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (query 19, line 57) (in query: SELECT count(arraySplit(number -> toUInt8(number), [arraySplit(x -> toUInt8(number), [])])) FROM numbers(10) GROUP BY number, [number] WITH ROLLUP settings group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0315f0 6. ./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 @ 0x000000002b030183 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 14. ./src/Functions/FunctionsMiscellaneous.h:67: DB::ExecutableFunctionExpression::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002cb52541 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 19. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x000000002fc4980d 20. DB::FunctionArrayMapped, DB::NameArraySplit>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000232575ed 21. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 23. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 24. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 25. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 26. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 27. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 28. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 29. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 2025.06.13 15:41:19.138750 [ 8430 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Array(Nothing)) of argument of function toUInt8: while executing 'FUNCTION toUInt8(number :: 0) -> toUInt8(number) UInt8 : 1': while executing 'FUNCTION arraySplit(number Array(Array(Nothing)) -> toUInt8(number) :: 1, array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String))) :: 2) -> arraySplit(number Array(Array(Nothing)) -> toUInt8(number), array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String)))) Array(Array(Array(Array(Nothing)))) : 4'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0315f0 6. ./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 @ 0x000000002b030183 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 14. ./src/Functions/FunctionsMiscellaneous.h:67: DB::ExecutableFunctionExpression::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002cb52541 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 19. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x000000002fc4980d 20. DB::FunctionArrayMapped, DB::NameArraySplit>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000232575ed 21. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 23. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 24. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 25. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 26. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 27. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 28. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 29. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:41:19.143247 [ 3931 ] {33792c66-1865-4f8d-9d8e-c70df002a8f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1421, line 1423) (in query: SELECT toModifiedJulianDay(NULL, NULL);) 2025.06.13 15:41:19.150821 [ 8442 ] {fe9ac90a-345b-4746-99f2-e75daad0097f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 512, line 512) (in query: SELECT emptyArrayUInt32(NULL, NULL);) 2025.06.13 15:41:19.159361 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:19.162698 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:19.212382 [ 3931 ] {aa01312c-d98b-4c70-89a9-51a614c1e302} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1422, line 1424) (in query: SELECT toModifiedJulianDayOrNull(NULL, NULL);) 2025.06.13 15:41:19.227665 [ 8442 ] {b88522d7-dc8e-4bcc-8c3f-6f91382a8611} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 513, line 513) (in query: SELECT emptyArrayUInt64(NULL, NULL);) 2025.06.13 15:41:19.230435 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:19.240811 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:19.329070 [ 8442 ] {51de6cb5-d6f2-440c-9cb3-a09a73c0d6fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 514, line 514) (in query: SELECT emptyArrayUInt8(NULL, NULL);) 2025.06.13 15:41:19.335731 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:19.405254 [ 8442 ] {5ed60526-6cea-4bec-9480-907708470f20} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 2, should be 0: In scope SELECT enabledProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 515, line 515) (in query: SELECT enabledProfiles(NULL, NULL);) 2025.06.13 15:41:19.544547 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 2, should be 0: In scope SELECT enabledProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:19.603398 [ 8442 ] {5c2dccdc-e3f8-4498-98bd-cd3acaf3e127} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 2, should be 0: In scope SELECT enabledRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 516, line 516) (in query: SELECT enabledRoles(NULL, NULL);) 2025.06.13 15:41:19.614738 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 2, should be 0: In scope SELECT enabledRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:19.668028 [ 8442 ] {55db31dc-30d2-4b60-b4ca-f4f6be591bc7} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 517, line 517) (in query: SELECT encodeURLComponent(NULL, NULL);) 2025.06.13 15:41:19.680521 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:19.763202 [ 8442 ] {4a77da8c-e42e-4e8d-9446-e37028ca6284} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 518, line 518) (in query: SELECT encodeURLFormComponent(NULL, NULL);) 2025.06.13 15:41:19.769077 [ 3931 ] {94953444-824c-4888-b031-9ce3b880df42} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 2, should be 1: In scope SELECT toNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1426, line 1428) (in query: SELECT toNullable(NULL, NULL);) 2025.06.13 15:41:19.776400 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:19.778705 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 2, should be 1: In scope SELECT toNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:19.881499 [ 8442 ] {422ef4b3-d128-499e-8a7d-57d01939bbfa} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 519, line 519) (in query: SELECT encodeXMLComponent(NULL, NULL);) 2025.06.13 15:41:19.898905 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:20.642601 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:20.748651 [ 5110 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:20.844431 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:20.854281 [ 8442 ] {ebcc2eb4-b7de-44fc-a85e-76c7d09a435a} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 2, should be 1: In scope SELECT erf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 525, line 525) (in query: SELECT erf(NULL, NULL);) 2025.06.13 15:41:20.862178 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 2, should be 1: In scope SELECT erf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:20.925088 [ 8442 ] {f1805ffc-3d48-4de8-9440-d491b20cd127} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 2, should be 1: In scope SELECT erfc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 526, line 526) (in query: SELECT erfc(NULL, NULL);) 2025.06.13 15:41:20.930886 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 2, should be 1: In scope SELECT erfc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:20.987159 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:21.026935 [ 8442 ] {08ccddd8-8ce5-4c7f-aba8-d5debc125cca} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 2, should be 1: In scope SELECT errorCodeToName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 527, line 527) (in query: SELECT errorCodeToName(NULL, NULL);) 2025.06.13 15:41:21.032562 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 2, should be 1: In scope SELECT errorCodeToName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:21.076302 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:21.162834 [ 8442 ] {17a6f337-94b2-4c11-ae7a-1b4ea2a9be34} executeQuery: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 528, line 528) (in query: SELECT estimateCompressionRatio(NULL, NULL);) 2025.06.13 15:41:21.180758 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:21.242929 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:21.286174 [ 5110 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:21.314242 [ 8442 ] {ea4bfd1f-7d03-4d5f-9e51-a54c29302b7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 2, should be 1: In scope SELECT exp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 530, line 530) (in query: SELECT exp(NULL, NULL);) 2025.06.13 15:41:21.320980 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 2, should be 1: In scope SELECT exp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:21.416062 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:21.425447 [ 8442 ] {9cff9513-b303-4e5f-b969-69dea082377c} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 2, should be 1: In scope SELECT exp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 531, line 531) (in query: SELECT exp10(NULL, NULL);) 2025.06.13 15:41:21.431906 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 2, should be 1: In scope SELECT exp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:21.548045 [ 8442 ] {b56956b6-b68b-4945-b9a9-1d316639f3ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 2, should be 1: In scope SELECT exp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 532, line 532) (in query: SELECT exp2(NULL, NULL);) 2025.06.13 15:41:21.556281 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 2, should be 1: In scope SELECT exp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:21.618907 [ 5110 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:21.664773 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:21.739978 [ 8442 ] {b1baa0ad-d703-4f7e-baca-38e2a2bcea8b} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 534, line 534) (in query: SELECT exponentialTimeDecayedAvg(NULL, NULL);) 2025.06.13 15:41:21.745502 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:21.763493 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:21.780552 [ 8442 ] {ee869efd-70e3-4a7f-95f6-e8f41961f831} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 535, line 535) (in query: SELECT exponentialTimeDecayedCount(NULL, NULL);) 2025.06.13 15:41:21.816998 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:21.850257 [ 8442 ] {d8e95cf1-ded3-420c-ac0a-2bd513ebc50e} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 536, line 536) (in query: SELECT exponentialTimeDecayedMax(NULL, NULL);) 2025.06.13 15:41:21.856621 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:21.858633 [ 5110 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:21.912936 [ 8431 ] {b024134a-80c1-4888-bbb3-b4973f1a56c8} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictGet('02176_test_complex_key_dictionary', 'value', ([0], '0')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46410) (comment: 02176_dict_get_has_implicit_key_cast.sql) (query 24, line 57) (in query: SELECT dictGet('02176_test_complex_key_dictionary', 'value', tuple([0], '0'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b038010 6. ./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 @ 0x000000002b036ba3 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], 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) @ 0x000000002addf493 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 18. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25278e 19. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e252fc4 20. ./src/Dictionaries/IDictionary.h:165: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000028a27899 21. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f43a9f 22. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 23. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 25. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 2025.06.13 15:41:21.913874 [ 8442 ] {67cc8d7c-e04e-4308-af13-7018af92ef4a} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 537, line 537) (in query: SELECT exponentialTimeDecayedSum(NULL, NULL);) 2025.06.13 15:41:21.918608 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:21.927672 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:22.015857 [ 8431 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictGet('02176_test_complex_key_dictionary', 'value', ([0], '0')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b038010 6. ./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 @ 0x000000002b036ba3 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], 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) @ 0x000000002addf493 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 18. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25278e 19. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e252fc4 20. ./src/Dictionaries/IDictionary.h:165: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000028a27899 21. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f43a9f 22. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 23. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 25. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 2025.06.13 15:41:22.123297 [ 5110 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:22.322836 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:22.379729 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:22.451342 [ 5110 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:22.504640 [ 8099 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:22.510820 [ 4107 ] {bff287b6-97f7-4b5b-af4e-91415608c18c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46434) (comment: 03269_partition_key_not_in_set.sql) (query 15, line 51) (in query: SELECT count() FROM 03269_single_non_monotonic WHERE id NOT IN (6, 38);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f585dc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f5af07 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f54898 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f54302 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dd53bf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dcd2b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e828f 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003221c43f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 2025.06.13 15:41:22.564711 [ 4107 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f585dc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f5af07 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f54898 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f54302 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dd53bf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dcd2b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e828f 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003221c43f 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:41:22.598664 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:23.121130 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:23.420178 [ 8442 ] {30683185-1188-4564-933f-a3a17c36f62f} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 2, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 546, line 546) (in query: SELECT extractTextFromHTML(NULL, NULL);) 2025.06.13 15:41:23.431663 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 2, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:23.622619 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:23.641461 [ 8442 ] {d77721e4-d491-4883-8ff4-1fe4aee6fc32} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 2, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 548, line 548) (in query: SELECT extractURLParameterNames(NULL, NULL);) 2025.06.13 15:41:23.642910 [ 8431 ] {4601d47d-c422-4601-9047-73c4de4beb6b} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictHas('02176_test_complex_key_dictionary', ([0], '0')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46410) (comment: 02176_dict_get_has_implicit_key_cast.sql) (query 29, line 63) (in query: SELECT dictHas('02176_test_complex_key_dictionary', tuple([0], '0'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b038010 6. ./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 @ 0x000000002b036ba3 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], 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) @ 0x000000002addf493 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 18. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25278e 19. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e252fc4 20. ./src/Dictionaries/IDictionary.h:165: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000028a27899 21. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f582fa 22. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 23. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 25. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 2025.06.13 15:41:23.648548 [ 8431 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictHas('02176_test_complex_key_dictionary', ([0], '0')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b038010 6. ./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 @ 0x000000002b036ba3 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], 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) @ 0x000000002addf493 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 18. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25278e 19. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e252fc4 20. ./src/Dictionaries/IDictionary.h:165: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x0000000028a27899 21. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f582fa 22. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 23. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 25. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 26. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 27. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 28. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 2025.06.13 15:41:23.648162 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 2, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:23.804754 [ 8442 ] {2513de28-3cce-43d6-b676-de735df10d2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 2, should be 1: In scope SELECT extractURLParameters(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 549, line 549) (in query: SELECT extractURLParameters(NULL, NULL);) 2025.06.13 15:41:23.819019 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 2, should be 1: In scope SELECT extractURLParameters(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:23.922830 [ 3931 ] {6bec0c13-628b-4821-a72e-a3d0dd926712} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 2, should be 1: In scope SELECT toStringCutToZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1455, line 1457) (in query: SELECT toStringCutToZero(NULL, NULL);) 2025.06.13 15:41:23.930059 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 2, should be 1: In scope SELECT toStringCutToZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:24.036857 [ 8442 ] {a706c3f8-04ff-4fb1-81cd-01861778713e} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 2, should be 1: In scope SELECT factorial(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 550, line 550) (in query: SELECT factorial(NULL, NULL);) 2025.06.13 15:41:24.063316 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 2, should be 1: In scope SELECT factorial(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:24.246398 [ 4107 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:24.263523 [ 3894 ] {b9f82eb7-abc0-48cf-8245-740cd477ca88} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43642) (comment: 01890_jit_aggregation_function_sum_long.sql) (in query: DROP DATABASE IF EXISTS test_l2zkv5iy SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:41:24.266377 [ 3894 ] {b9f82eb7-abc0-48cf-8245-740cd477ca88} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:24.460840 [ 8442 ] {fda42647-16f7-4839-b356-00c0ae905e44} executeQuery: Code: 48. DB::Exception: file is only implemented for type String: In scope SELECT file(NULL, NULL). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 553, line 553) (in query: SELECT file(NULL, NULL);) 2025.06.13 15:41:24.466410 [ 8442 ] {} TCPHandler: Code: 48. DB::Exception: file is only implemented for type String: In scope SELECT file(NULL, NULL). (NOT_IMPLEMENTED) 2025.06.13 15:41:24.526014 [ 5110 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:24.578958 [ 3931 ] {b689e725-4996-47a8-8472-d3d44c772864} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 2, should be 1: In scope SELECT toTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1459, line 1461) (in query: SELECT toTypeName(NULL, NULL);) 2025.06.13 15:41:24.584864 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 2, should be 1: In scope SELECT toTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:24.780431 [ 3894 ] {8d9b6ac7-e47f-4252-9f63-4da9722717b8} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Nullable(UInt8)): While executing AggregatingTransform. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56810) (comment: 02419_contingency_array_nullable.sql) (query 1, line 1) (in query: SELECT contingency(1, [1, NULL]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002fa25b43 6. ./src/AggregateFunctions/UniqVariadicHash.h:49: DB::UniqVariadicHash::apply(unsigned long, DB::IColumn const**, unsigned long) @ 0x0000000026bb297e 7. ./src/AggregateFunctions/CrossTab.h:147: DB::IAggregateFunctionHelper>::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000027ad9e4e 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1365: DB::Aggregator::addBatchSinglePlace(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char*, DB::Arena*) @ 0x000000002d6b77b2 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1314: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x000000002d6b7fe4 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1575: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6bc45d 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d8bba4 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d85ecd 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:41:24.803407 [ 3894 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Nullable(UInt8)): While executing AggregatingTransform. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002fa25b43 6. ./src/AggregateFunctions/UniqVariadicHash.h:49: DB::UniqVariadicHash::apply(unsigned long, DB::IColumn const**, unsigned long) @ 0x0000000026bb297e 7. ./src/AggregateFunctions/CrossTab.h:147: DB::IAggregateFunctionHelper>::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000027ad9e4e 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1365: DB::Aggregator::addBatchSinglePlace(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char*, DB::Arena*) @ 0x000000002d6b77b2 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1314: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x000000002d6b7fe4 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1575: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6bc45d 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d8bba4 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d85ecd 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:41:24.850240 [ 3931 ] {a3cfd466-a022-4362-9b26-31aabc281b6e} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt128. Actual Nullable(Nothing): In scope SELECT toUInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1461, line 1463) (in query: SELECT toUInt128OrDefault(NULL, NULL);) 2025.06.13 15:41:24.862400 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt128. Actual Nullable(Nothing): In scope SELECT toUInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:24.945227 [ 8442 ] {28f72bad-4dd0-4d18-b2ba-d38eccff5863} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 2, should be 1: In scope SELECT finalizeAggregation(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 557, line 557) (in query: SELECT finalizeAggregation(NULL, NULL);) 2025.06.13 15:41:24.960327 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 2, should be 1: In scope SELECT finalizeAggregation(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:25.025271 [ 8442 ] {ddbfa268-4809-486a-a0f0-b51665d9f351} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 2, should be 1: In scope SELECT firstLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 558, line 558) (in query: SELECT firstLine(NULL, NULL);) 2025.06.13 15:41:25.029983 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 2, should be 1: In scope SELECT firstLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:25.122701 [ 8442 ] {51e10e91-f008-44f5-ab00-8f0bbe62ecc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 559, line 559) (in query: SELECT firstSignificantSubdomain(NULL, NULL);) 2025.06.13 15:41:25.127901 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:25.405002 [ 3931 ] {8a05e395-5958-4f53-a672-3c46fcfbd146} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt16. Actual Nullable(Nothing): In scope SELECT toUInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1465, line 1467) (in query: SELECT toUInt16OrDefault(NULL, NULL);) 2025.06.13 15:41:25.412556 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt16. Actual Nullable(Nothing): In scope SELECT toUInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:25.439767 [ 8099 ] {2887145f-2132-4bb1-810a-bef8ef3bd961} executeQuery: Code: 36. DB::Exception: Too many groups for analysis of variance (should be no more than 1048576, got 18446744073709551615): While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56834) (comment: 02874_analysis_of_variance_overflow.sql) (query 1, line 1) (in query: SELECT analysisOfVariance(1, 18446744073709551615);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000017cdbfef 5. ./src/AggregateFunctions/Moments.h:463: DB::AnalysisOfVarianceMoments::add(double, unsigned long) @ 0x0000000028234aa3 6. ./src/AggregateFunctions/IAggregateFunction.h:552: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000282322dc 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1365: DB::Aggregator::addBatchSinglePlace(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char*, DB::Arena*) @ 0x000000002d6b77b2 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1314: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x000000002d6b7fe4 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1575: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6bc45d 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d8bba4 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d85ecd 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:41:25.446525 [ 8099 ] {} TCPHandler: Code: 36. DB::Exception: Too many groups for analysis of variance (should be no more than 1048576, got 18446744073709551615): While executing AggregatingTransform. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000017cdbfef 5. ./src/AggregateFunctions/Moments.h:463: DB::AnalysisOfVarianceMoments::add(double, unsigned long) @ 0x0000000028234aa3 6. ./src/AggregateFunctions/IAggregateFunction.h:552: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000282322dc 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1365: DB::Aggregator::addBatchSinglePlace(unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, char*, DB::Arena*) @ 0x000000002d6b77b2 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1314: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x000000002d6b7fe4 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1575: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6bc45d 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d8bba4 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d85ecd 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:41:25.574827 [ 8442 ] {42a74773-2f9b-441a-ad99-a01fb08508f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 562, line 562) (in query: SELECT firstSignificantSubdomainRFC(NULL, NULL);) 2025.06.13 15:41:25.584199 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:25.672231 [ 8442 ] {25b70627-e3e5-4148-aaed-2e8521b9f053} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 563, line 563) (in query: SELECT firstValueRespectNulls(NULL, NULL);) 2025.06.13 15:41:25.688645 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:26.062710 [ 8442 ] {145b2786-aaca-4725-bbdc-b85e394d851c} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 565, line 565) (in query: SELECT first_value_respect_nulls(NULL, NULL);) 2025.06.13 15:41:26.065761 [ 3931 ] {71b52249-16b5-4a95-8d49-6f0806a014b3} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt256. Actual Nullable(Nothing): In scope SELECT toUInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1469, line 1471) (in query: SELECT toUInt256OrDefault(NULL, NULL);) 2025.06.13 15:41:26.085093 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:26.090319 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt256. Actual Nullable(Nothing): In scope SELECT toUInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:26.234194 [ 8442 ] {f37c8aa3-cf13-47c7-80e4-c4123cc5df3b} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 566, line 566) (in query: SELECT flameGraph(NULL, NULL);) 2025.06.13 15:41:26.251120 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:26.428904 [ 8442 ] {3990fa54-c169-4a45-8677-bd981929661f} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT flatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 567, line 567) (in query: SELECT flatten(NULL, NULL);) 2025.06.13 15:41:26.462256 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT flatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:26.574736 [ 8442 ] {e160a728-7b36-4d33-a7a5-d60b57e0a5c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 2, should be 1: In scope SELECT flattenTuple(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 568, line 568) (in query: SELECT flattenTuple(NULL, NULL);) 2025.06.13 15:41:26.598968 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 2, should be 1: In scope SELECT flattenTuple(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:26.737652 [ 3931 ] {f61b5b40-3619-4fb7-8131-4f0d5e2ed33a} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt32. Actual Nullable(Nothing): In scope SELECT toUInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1473, line 1475) (in query: SELECT toUInt32OrDefault(NULL, NULL);) 2025.06.13 15:41:26.743368 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt32. Actual Nullable(Nothing): In scope SELECT toUInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:26.909146 [ 3005 ] {} test_8ow60ayp.mutations_and_quorum1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_8ow60ayp/test_01090/mutations_and_quorum/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000030587a41 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6856: DB::StorageReplicatedMergeTree::dropPartNoWaitNoThrow(String const&) @ 0x000000003068cc14 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3192: DB::MergeTreeData::clearEmptyParts() @ 0x0000000030cb7228 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:208: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x00000000310be34f 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000310bc942 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:27.335818 [ 3931 ] {383af400-6d99-443d-bb05-a29a3a19023b} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt64. Actual Nullable(Nothing): In scope SELECT toUInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1477, line 1479) (in query: SELECT toUInt64OrDefault(NULL, NULL);) 2025.06.13 15:41:27.346554 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt64. Actual Nullable(Nothing): In scope SELECT toUInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:27.437205 [ 8442 ] {1fd6951c-8fc3-4c97-9b3e-6aa919e60b34} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 2, should be 1: In scope SELECT formatQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 573, line 573) (in query: SELECT formatQuery(NULL, NULL);) 2025.06.13 15:41:27.447590 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 2, should be 1: In scope SELECT formatQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:27.510913 [ 8442 ] {1a013e6e-70b0-4671-b0fb-75733d4b13ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 574, line 574) (in query: SELECT formatQueryOrNull(NULL, NULL);) 2025.06.13 15:41:27.522474 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:27.641574 [ 8442 ] {91779de8-5a04-4324-b0b6-140807d4c1cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 575, line 575) (in query: SELECT formatQuerySingleLine(NULL, NULL);) 2025.06.13 15:41:27.648942 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:27.702859 [ 8442 ] {14a8ec80-e653-43b0-b63b-09f639ef5907} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 576, line 576) (in query: SELECT formatQuerySingleLineOrNull(NULL, NULL);) 2025.06.13 15:41:27.708190 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:27.807867 [ 8442 ] {be7baead-9f62-469f-b67a-49233ce0f457} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 577, line 577) (in query: SELECT formatReadableDecimalSize(NULL, NULL);) 2025.06.13 15:41:27.812415 [ 3931 ] {3ee43718-0e4e-4dd7-9cfa-65ce210fa30e} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt8. Actual Nullable(Nothing): In scope SELECT toUInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1481, line 1483) (in query: SELECT toUInt8OrDefault(NULL, NULL);) 2025.06.13 15:41:27.814860 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:27.818490 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt8. Actual Nullable(Nothing): In scope SELECT toUInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:27.871487 [ 8442 ] {a8592c97-6cba-4bee-8532-0ab4337745ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 2, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 578, line 578) (in query: SELECT formatReadableQuantity(NULL, NULL);) 2025.06.13 15:41:27.877329 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 2, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:27.955582 [ 8442 ] {bc3ed52b-6702-4b17-9f96-13c132e6bfab} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 579, line 579) (in query: SELECT formatReadableSize(NULL, NULL);) 2025.06.13 15:41:27.964376 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:28.033427 [ 3821 ] {041d4483-155d-4140-9e39-079a9f860a8d} executeQuery: Code: 388. DB::Exception: Cannot select parts for optimization: there are no parts in partition 123. (CANNOT_ASSIGN_OPTIMIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57016) (comment: 02439_merge_selecting_partitions.sql) (query 14, line 20) (in query: optimize table rmt partition tuple(123);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6144: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x000000003067a654 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6306: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000030675808 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:41:28.038115 [ 3821 ] {} TCPHandler: Code: 388. DB::Exception: Cannot select parts for optimization: there are no parts in partition 123. (CANNOT_ASSIGN_OPTIMIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6144: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x000000003067a654 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6306: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000030675808 6. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:41:28.088381 [ 8442 ] {05a620fb-5d58-4fc7-b23f-5d696bca3d98} executeQuery: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 581, line 581) (in query: SELECT formatRow(NULL, NULL);) 2025.06.13 15:41:28.111729 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:28.202316 [ 8442 ] {a97cf9d4-cb98-4f43-8917-d5df1493a311} executeQuery: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 582, line 582) (in query: SELECT formatRowNoNewline(NULL, NULL);) 2025.06.13 15:41:28.226468 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:28.300108 [ 3931 ] {5406e940-6c51-49f7-ac2e-a9590f57a026} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UUID. Actual Nullable(Nothing): In scope SELECT toUUIDOrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1486, line 1488) (in query: SELECT toUUIDOrDefault(NULL, NULL);) 2025.06.13 15:41:28.312714 [ 3931 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UUID. Actual Nullable(Nothing): In scope SELECT toUUIDOrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:41:28.328924 [ 8442 ] {bb6188c7-08f4-4a1c-ba23-693223d7a81b} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 2, should be 1: In scope SELECT fragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 583, line 583) (in query: SELECT fragment(NULL, NULL);) 2025.06.13 15:41:28.360353 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 2, should be 1: In scope SELECT fragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:28.420045 [ 8442 ] {4b34f137-5d0a-4adc-ad50-3f70adb37569} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 584, line 584) (in query: SELECT fromDaysSinceYearZero(NULL, NULL);) 2025.06.13 15:41:28.426621 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:28.432894 [ 4107 ] {e3910dea-ee6f-4210-b8a9-a75d93312ca9} executeQuery: Code: 57. DB::Exception: Table test_9.tp already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56846) (comment: 02968_projection_merge.sql) (query 11, line 31) (in query: CREATE TABLE tp (`type` Int32, `eventcnt` UInt64, `sign` Int8, PROJECTION p (SELECT type, sum(eventcnt) GROUP BY type)) ENGINE = CollapsingMergeTree(sign) ORDER BY type SETTINGS deduplicate_merge_projection_mode = 'rebuild', index_granularity = 4493, min_bytes_for_wide_part = 382269455, 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 = 302539457, compact_parts_max_bytes_to_buffer = 172804858, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 6853456, merge_max_block_size = 14275, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 4340471139, index_granularity_bytes = 28469974, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 29, 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 = 51058, primary_key_compress_block_size = 95943, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:41:28.444563 [ 4107 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.tp already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:41:28.525440 [ 8442 ] {32178047-6f64-4474-be5a-5cf840187161} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 585, line 585) (in query: SELECT fromDaysSinceYearZero32(NULL, NULL);) 2025.06.13 15:41:28.531445 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:28.650908 [ 8442 ] {8ac1b54f-66d5-4bb6-ba65-1f5842bd1bb7} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 586, line 586) (in query: SELECT fromModifiedJulianDay(NULL, NULL);) 2025.06.13 15:41:28.665760 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:28.764719 [ 4107 ] {83039876-a718-4ae7-8165-2d41213d22c2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43700) (comment: 02024_create_dictionary_with_comment.sql) (in query: DROP DATABASE IF EXISTS test_7rzhqoto SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:41:28.772602 [ 4107 ] {83039876-a718-4ae7-8165-2d41213d22c2} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:28.801430 [ 8442 ] {1cfef7ba-2a94-44b3-8956-dfd4f74cb2ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 587, line 587) (in query: SELECT fromModifiedJulianDayOrNull(NULL, NULL);) 2025.06.13 15:41:28.815977 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:28.944126 [ 3931 ] {dfcc7248-2216-43bf-a1f4-70661ce38cd6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1490, line 1492) (in query: SELECT toUnixTimestamp64Micro(NULL, NULL);) 2025.06.13 15:41:28.950432 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:29.059130 [ 3931 ] {b93d6aac-acd9-45f8-912b-1e44f8118592} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1491, line 1493) (in query: SELECT toUnixTimestamp64Milli(NULL, NULL);) 2025.06.13 15:41:29.080752 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:29.155940 [ 3931 ] {056f9b7d-c1e0-4091-9e74-5a5fd2f7d6ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1492, line 1494) (in query: SELECT toUnixTimestamp64Nano(NULL, NULL);) 2025.06.13 15:41:29.175333 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:29.260095 [ 3931 ] {657eab1b-fe9d-4d69-aa2e-6e2833807a3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Second(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1493, line 1495) (in query: SELECT toUnixTimestamp64Second(NULL, NULL);) 2025.06.13 15:41:29.265475 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Second(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:29.350733 [ 3931 ] {00abe751-42dc-45d9-a855-67e24979dbab} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT toValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1494, line 1496) (in query: SELECT toValidUTF8(NULL, NULL);) 2025.06.13 15:41:29.364133 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT toValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:30.342939 [ 8442 ] {7e830b67-4a71-48e8-a7db-825e534c93fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT fullHostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 596, line 596) (in query: SELECT fullHostName(NULL, NULL);) 2025.06.13 15:41:30.350223 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT fullHostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:30.447491 [ 8430 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:30.553478 [ 8430 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:30.671711 [ 8430 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:30.679775 [ 3931 ] {1d1b734b-704b-40bc-907a-fae763754d09} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT today(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1503, line 1505) (in query: SELECT today(NULL, NULL);) 2025.06.13 15:41:30.694318 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT today(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:30.781179 [ 8099 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:30.795597 [ 3931 ] {455d3655-c664-4e23-85b9-b84acd400228} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 2, should be 1: In scope SELECT tokens(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1504, line 1506) (in query: SELECT tokens(NULL, NULL);) 2025.06.13 15:41:30.803737 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 2, should be 1: In scope SELECT tokens(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:30.868681 [ 8430 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:30.950640 [ 8430 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:31.004649 [ 8442 ] {d34b1b3d-9d7f-4f5b-8897-2f32f0cce2f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 2, should be 1: In scope SELECT generateSerialID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 601, line 601) (in query: SELECT generateSerialID(NULL, NULL);) 2025.06.13 15:41:31.017301 [ 9636 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:31.050274 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 2, should be 1: In scope SELECT generateSerialID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:31.213170 [ 3931 ] {afeafe46-d302-4f1a-bd11-3ec7850087f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 2, should be 1: In scope SELECT topLevelDomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1507, line 1509) (in query: SELECT topLevelDomain(NULL, NULL);) 2025.06.13 15:41:31.237789 [ 8442 ] {b1a8271d-c20f-4585-9ac4-243a17382903} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: Nullable(Nothing): In scope SELECT generateSnowflakeID(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 602, line 602) (in query: SELECT generateSnowflakeID(NULL, NULL);) 2025.06.13 15:41:31.249195 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 2, should be 1: In scope SELECT topLevelDomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:31.263306 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: Nullable(Nothing): In scope SELECT generateSnowflakeID(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:31.376098 [ 3931 ] {ad2b9137-d09b-4e43-9083-8dcdfcab8f7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 2, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1508, line 1510) (in query: SELECT topLevelDomainRFC(NULL, NULL);) 2025.06.13 15:41:31.396033 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 2, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:31.512119 [ 3931 ] {5eef3553-9f30-4202-8138-016e04f0fe5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 2, should be 0: In scope SELECT transactionID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1509, line 1511) (in query: SELECT transactionID(NULL, NULL);) 2025.06.13 15:41:31.523849 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 2, should be 0: In scope SELECT transactionID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:31.545710 [ 8430 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:31.570003 [ 8442 ] {28f3a068-c9bc-48ed-9a65-fac9e0684f80} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 604, line 604) (in query: SELECT generateUUIDv4(NULL, NULL);) 2025.06.13 15:41:31.584843 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:31.686086 [ 3931 ] {a5ce2504-8668-43d5-99f5-a77042b4dd5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1510, line 1512) (in query: SELECT transactionLatestSnapshot(NULL, NULL);) 2025.06.13 15:41:31.715842 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:31.721045 [ 8442 ] {80fa6a00-5dab-4edd-9bde-0e98c1ed38c7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv7(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 605, line 605) (in query: SELECT generateUUIDv7(NULL, NULL);) 2025.06.13 15:41:31.741027 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv7(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:31.831557 [ 3931 ] {5871736c-9864-4b5e-b165-d986e47254bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1511, line 1513) (in query: SELECT transactionOldestSnapshot(NULL, NULL);) 2025.06.13 15:41:31.852249 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:31.866153 [ 8442 ] {769e952c-ca41-4a60-b09e-9fa36b391d2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 2, should be 4: In scope SELECT geoDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 606, line 606) (in query: SELECT geoDistance(NULL, NULL);) 2025.06.13 15:41:31.893680 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 2, should be 4: In scope SELECT geoDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:31.992940 [ 3931 ] {dc675257-d52e-4ccd-bbc9-5a2771ee6e56} executeQuery: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 2, should be 3 or 4: In scope SELECT transform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1512, line 1514) (in query: SELECT transform(NULL, NULL);) 2025.06.13 15:41:32.005235 [ 8442 ] {becbd3ea-4be8-40b8-8e8e-a5015b2644f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 2, should be 3: In scope SELECT geoToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 607, line 607) (in query: SELECT geoToH3(NULL, NULL);) 2025.06.13 15:41:32.005504 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 2, should be 3 or 4: In scope SELECT transform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:32.015248 [ 9636 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:32.025943 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 2, should be 3: In scope SELECT geoToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:32.117633 [ 3931 ] {f3e70f7e-ff68-41b6-bad7-32c67eef5797} executeQuery: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 2, should be 3: In scope SELECT translate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1513, line 1515) (in query: SELECT translate(NULL, NULL);) 2025.06.13 15:41:32.133416 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 2, should be 3: In scope SELECT translate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:32.238831 [ 3931 ] {7abf7f32-a917-4b10-ae30-aab099253404} executeQuery: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 2, should be 3: In scope SELECT translateUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1514, line 1516) (in query: SELECT translateUTF8(NULL, NULL);) 2025.06.13 15:41:32.262273 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 2, should be 3: In scope SELECT translateUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:32.325770 [ 4098 ] {c93fe69b-6b87-4333-9622-69d04d5b1329} executeQuery: Code: 43. DB::Exception: First argument of function 'arrayShuffle' must be array: In scope SELECT arrayShuffle(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46436) (comment: 02523_array_shuffle.sql) (query 68, line 68) (in query: SELECT arrayShuffle(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000230c1bf9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:41:32.333691 [ 8442 ] {5bf7e3bd-f859-449b-8a97-8ae5b05b701c} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 2, should be 1: In scope SELECT geohashDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 609, line 609) (in query: SELECT geohashDecode(NULL, NULL);) 2025.06.13 15:41:32.348416 [ 4098 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function 'arrayShuffle' must be array: In scope SELECT arrayShuffle(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000230c1bf9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:41:32.352709 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 2, should be 1: In scope SELECT geohashDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:32.452019 [ 9636 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:32.639162 [ 8442 ] {21e6bb8e-ccb4-4354-b9fb-8091e30b3cc4} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 2, should be 5: In scope SELECT geohashesInBox(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 611, line 611) (in query: SELECT geohashesInBox(NULL, NULL);) 2025.06.13 15:41:32.651695 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 2, should be 5: In scope SELECT geohashesInBox(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:32.674054 [ 4098 ] {1c0f3cd5-aaed-44f7-8f7b-1f25623539c5} executeQuery: Code: 43. DB::Exception: Illegal type String of arguments of function arrayShuffle (must be UInt or Int): In scope SELECT arrayShuffle([1], 'a'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46436) (comment: 02523_array_shuffle.sql) (query 69, line 69) (in query: SELECT arrayShuffle([1], 'a');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. auto DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(auto)::operator()(auto) const @ 0x00000000230c2a03 6. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000230c1a0b 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:41:32.680079 [ 4098 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of arguments of function arrayShuffle (must be UInt or Int): In scope SELECT arrayShuffle([1], 'a'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. auto DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(auto)::operator()(auto) const @ 0x00000000230c2a03 6. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000230c1a0b 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:41:32.737708 [ 8099 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:32.820451 [ 4098 ] {6f1734b9-c19f-4882-83c5-42a21208ea95} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of arguments of function arrayShuffle (must be UInt or Int): In scope SELECT arrayShuffle([1], 1.1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46436) (comment: 02523_array_shuffle.sql) (query 70, line 70) (in query: SELECT arrayShuffle([1], 1.1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. auto DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(auto)::operator()(auto) const @ 0x00000000230c2a03 6. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000230c1a0b 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:41:32.820506 [ 8442 ] {6e0b27e5-f5b6-4a1c-94bd-b83ec4f5271b} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 612, line 612) (in query: SELECT getClientHTTPHeader(NULL, NULL);) 2025.06.13 15:41:32.832499 [ 8442 ] {} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.06.13 15:41:32.842029 [ 4098 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of arguments of function arrayShuffle (must be UInt or Int): In scope SELECT arrayShuffle([1], 1.1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. auto DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const::'lambda'(auto)::operator()(auto) const @ 0x00000000230c2a03 6. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000230c1a0b 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:41:32.929342 [ 8442 ] {a2522b0f-01dc-4cd4-8dde-f4ebea68678a} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 2, should be 1: In scope SELECT getMacro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 613, line 613) (in query: SELECT getMacro(NULL, NULL);) 2025.06.13 15:41:32.950975 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 2, should be 1: In scope SELECT getMacro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:33.071506 [ 8442 ] {ae3846f7-8ba7-4ebd-a9cf-41c0a6b8ef35} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 2, should be 1: In scope SELECT getMaxTableNameLengthForDatabase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 614, line 614) (in query: SELECT getMaxTableNameLengthForDatabase(NULL, NULL);) 2025.06.13 15:41:33.080287 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 2, should be 1: In scope SELECT getMaxTableNameLengthForDatabase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:33.113302 [ 4098 ] {dacef81b-b563-40ac-9627-38b197624434} executeQuery: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 3.: In scope SELECT arrayShuffle([1], 51966, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46436) (comment: 02523_array_shuffle.sql) (query 71, line 71) (in query: SELECT arrayShuffle([1], 0xcafe, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int const&, unsigned long&&) @ 0x00000000230c270f 5. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000230c1b31 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:41:33.137159 [ 4098 ] {} TCPHandler: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 3.: In scope SELECT arrayShuffle([1], 51966, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int const&, unsigned long&&) @ 0x00000000230c270f 5. DB::FunctionArrayShuffleImpl::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000230c1b31 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:41:33.229471 [ 8442 ] {624b345e-66f3-4904-b49b-65ad44b99d99} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 2, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 615, line 615) (in query: SELECT getOSKernelVersion(NULL, NULL);) 2025.06.13 15:41:33.234458 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 2, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:33.314444 [ 8442 ] {6f82b650-a226-4738-a468-e63de11a3c32} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 2, should be 1: In scope SELECT getServerPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 616, line 616) (in query: SELECT getServerPort(NULL, NULL);) 2025.06.13 15:41:33.384893 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 2, should be 1: In scope SELECT getServerPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:33.396878 [ 3931 ] {72024c66-b5ec-4491-9209-b8a632a54fdb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1520, line 1523) (in query: SELECT tryBase58Decode(NULL, NULL);) 2025.06.13 15:41:33.408927 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:33.470656 [ 8442 ] {4e363230-ac94-47af-82fe-89b33b277a66} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 2, should be 1: In scope SELECT getSetting(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 617, line 617) (in query: SELECT getSetting(NULL, NULL);) 2025.06.13 15:41:33.492149 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 2, should be 1: In scope SELECT getSetting(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:33.494614 [ 3931 ] {b26bab25-6d78-4047-9644-0802dde2fa46} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1521, line 1524) (in query: SELECT tryBase64Decode(NULL, NULL);) 2025.06.13 15:41:33.504362 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:33.682278 [ 3931 ] {f01eaed1-d474-4435-9431-5bb1e56524fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1522, line 1525) (in query: SELECT tryBase64URLDecode(NULL, NULL);) 2025.06.13 15:41:33.714655 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:33.841361 [ 8442 ] {879e5d55-d696-424c-8346-8bbdd8f67560} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 2, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 619, line 619) (in query: SELECT getSizeOfEnumType(NULL, NULL);) 2025.06.13 15:41:33.851560 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 2, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:33.952674 [ 8442 ] {0332bfcf-8452-4818-8be5-7f8f6938ee1b} 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(NULL, NULL). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 620, line 620) (in query: SELECT getSubcolumn(NULL, NULL);) 2025.06.13 15:41:33.954909 [ 3931 ] {9a846675-8cbe-43e4-b7ef-d268654af357} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 2, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1524, line 1527) (in query: SELECT tryIdnaEncode(NULL, NULL);) 2025.06.13 15:41:34.035032 [ 8442 ] {} 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(NULL, NULL). (ILLEGAL_COLUMN) 2025.06.13 15:41:34.038411 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 2, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:34.101427 [ 3931 ] {360b02b8-7491-4c6c-8aa1-dc6e770cb6af} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 2, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1525, line 1528) (in query: SELECT tryPunycodeDecode(NULL, NULL);) 2025.06.13 15:41:34.117378 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 2, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:34.122643 [ 8442 ] {9d3179ce-7b50-4530-b341-42d0d5e040bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 2, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 621, line 621) (in query: SELECT getTypeSerializationStreams(NULL, NULL);) 2025.06.13 15:41:34.154949 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 2, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:35.392895 [ 3931 ] {08dd93db-49de-441a-a6a7-9b9090f10294} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1533, line 1536) (in query: SELECT tupleElement(NULL, NULL);) 2025.06.13 15:41:35.472251 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:35.629846 [ 8442 ] {9d975ee7-fc8c-4d28-9b75-7a56c0fdc4b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 2, should be 1: In scope SELECT globalVariable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 630, line 630) (in query: SELECT globalVariable(NULL, NULL);) 2025.06.13 15:41:35.643047 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 2, should be 1: In scope SELECT globalVariable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:35.803461 [ 8442 ] {740af244-aab8-4989-86f2-d2be714bb79d} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 2, should be 4: In scope SELECT greatCircleAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 631, line 631) (in query: SELECT greatCircleAngle(NULL, NULL);) 2025.06.13 15:41:35.813241 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 2, should be 4: In scope SELECT greatCircleAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:35.897572 [ 8442 ] {6f2edf2e-8845-4d53-a3ec-3b75b0cf1d47} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 2, should be 4: In scope SELECT greatCircleDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 632, line 632) (in query: SELECT greatCircleDistance(NULL, NULL);) 2025.06.13 15:41:35.916418 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 2, should be 4: In scope SELECT greatCircleDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:36.062850 [ 9636 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:36.537197 [ 9642 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:37.121144 [ 3931 ] {1f1e107a-876e-4f06-895b-b67e548c11ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 2, should be 1: In scope SELECT tupleNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1544, line 1547) (in query: SELECT tupleNames(NULL, NULL);) 2025.06.13 15:41:37.132991 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 2, should be 1: In scope SELECT tupleNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:37.187425 [ 7279 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:41:37.188584 [ 7279 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:41:37.197558 [ 9642 ] {a7055cd1-3522-41d6-9238-443606e4f23d} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58784) (comment: 00220_shard_with_totals_in_subquery_remote_and_limit.sql) (query 1, line 3) (in query: SELECT x FROM (SELECT count() AS x FROM remote('127.0.0.2', system.one) WITH TOTALS) LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:41:37.235191 [ 9642 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:41:37.255569 [ 3931 ] {d73a06f3-b02e-4066-9d3c-5a9a10df10d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 2, should be 1: In scope SELECT tupleNegate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1545, line 1548) (in query: SELECT tupleNegate(NULL, NULL);) 2025.06.13 15:41:37.273791 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 2, should be 1: In scope SELECT tupleNegate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:37.614389 [ 3931 ] {cf2aebdc-3ddf-4091-b5b9-d97e19c7e5c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 2, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1547, line 1550) (in query: SELECT tupleToNameValuePairs(NULL, NULL);) 2025.06.13 15:41:37.618972 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 2, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:37.745223 [ 3931 ] {1c784f0d-4444-479c-aacb-5fdfed79a7f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT ucase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1548, line 1551) (in query: SELECT ucase(NULL, NULL);) 2025.06.13 15:41:37.753052 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT ucase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:37.874710 [ 3931 ] {71d0de24-8074-4941-874b-f2f96d18cb5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 2, should be 1: In scope SELECT unbin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1549, line 1552) (in query: SELECT unbin(NULL, NULL);) 2025.06.13 15:41:37.881194 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 2, should be 1: In scope SELECT unbin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:37.951643 [ 3931 ] {e4080c18-8f13-4b66-a0f2-578884012860} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 2, should be 1: In scope SELECT unhex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1550, line 1553) (in query: SELECT unhex(NULL, NULL);) 2025.06.13 15:41:37.965002 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 2, should be 1: In scope SELECT unhex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:38.938409 [ 8431 ] {42f6e31b-6ac5-473d-a82b-4b919c5cb778} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57612) (comment: 02459_group_by_all.sql) (in query: DROP DATABASE IF EXISTS test_d8qpoit9 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:41:38.942312 [ 8431 ] {42f6e31b-6ac5-473d-a82b-4b919c5cb778} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:39.421363 [ 8442 ] {fa26a8eb-7fb4-4141-a05c-da30ee9abab0} executeQuery: Code: 43. DB::Exception: If groupConcat is used with two arguments, the second argument must be a constant String. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 651, line 651) (in query: SELECT groupConcat(NULL, NULL);) 2025.06.13 15:41:39.458129 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: If groupConcat is used with two arguments, the second argument must be a constant String. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:39.708794 [ 8442 ] {f21e3844-9515-4e9e-b771-6af574001fa7} executeQuery: Code: 43. DB::Exception: If groupConcat is used with two arguments, the second argument must be a constant String. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 653, line 653) (in query: SELECT group_concat(NULL, NULL);) 2025.06.13 15:41:39.761562 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: If groupConcat is used with two arguments, the second argument must be a constant String. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:39.852504 [ 8442 ] {a595946b-5b29-4465-b04b-4a400cac473c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 654, line 654) (in query: SELECT h3CellAreaM2(NULL, NULL);) 2025.06.13 15:41:39.866816 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:40.015974 [ 3931 ] {b29cc0e0-73d7-44d9-8f93-b09c23f01216} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT upper(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1561, line 1564) (in query: SELECT upper(NULL, NULL);) 2025.06.13 15:41:40.018889 [ 8442 ] {3bbc2cae-1514-4c78-840a-76b02225e228} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 655, line 655) (in query: SELECT h3CellAreaRads2(NULL, NULL);) 2025.06.13 15:41:40.027664 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT upper(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:40.028513 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:40.106836 [ 3931 ] {c57d1468-f648-4cfd-a3f8-3883b71525ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 2, should be 1: In scope SELECT upperUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1562, line 1565) (in query: SELECT upperUTF8(NULL, NULL);) 2025.06.13 15:41:40.155734 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 2, should be 1: In scope SELECT upperUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:40.222977 [ 3931 ] {9503901b-0768-4167-a67b-a3cf2df4edf0} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 2, should be 0: In scope SELECT uptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1563, line 1566) (in query: SELECT uptime(NULL, NULL);) 2025.06.13 15:41:40.229006 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 2, should be 0: In scope SELECT uptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:40.338797 [ 8442 ] {7ef1d115-18d8-4c8a-a8b9-f966b4b89ca0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 2, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 657, line 657) (in query: SELECT h3EdgeAngle(NULL, NULL);) 2025.06.13 15:41:40.350826 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 2, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:40.396207 [ 3931 ] {03c62815-79e7-4bc2-aa88-853bc5357415} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1564, line 1567) (in query: SELECT user(NULL, NULL);) 2025.06.13 15:41:40.401006 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:40.491972 [ 8442 ] {89d0724c-3f47-4a7d-92ea-9676b660de69} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 658, line 658) (in query: SELECT h3EdgeLengthKm(NULL, NULL);) 2025.06.13 15:41:40.499256 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:40.518025 [ 4107 ] {0ed9188d-1aec-45ab-a4df-c448ebba05a1} 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.20286.altinityantalya (altinity build)) (from [::1]:59086) (comment: 02867_storage_set_tsan.sh) (query 1, line 1) (in query: SELECT count() as a FROM numbers(10) WHERE number IN t1_02867), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:41:40.548649 [ 4107 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:41:40.667636 [ 8442 ] {76844975-a648-4863-919b-6f92855983bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 659, line 659) (in query: SELECT h3EdgeLengthM(NULL, NULL);) 2025.06.13 15:41:40.683268 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:40.795110 [ 8442 ] {425dfad0-8318-4296-89e5-32995be2e2d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 660, line 660) (in query: SELECT h3ExactEdgeLengthKm(NULL, NULL);) 2025.06.13 15:41:40.812138 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:40.919157 [ 8442 ] {61950689-8fba-4483-a6c5-d918e5b2148a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 661, line 661) (in query: SELECT h3ExactEdgeLengthM(NULL, NULL);) 2025.06.13 15:41:40.931971 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:41.061906 [ 8442 ] {5d4a344e-fa90-4e1a-a155-e2539f0ef9c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 662, line 662) (in query: SELECT h3ExactEdgeLengthRads(NULL, NULL);) 2025.06.13 15:41:41.073352 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:41.235897 [ 8442 ] {04fc1641-faf2-4258-9141-626819b62229} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 2, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 663, line 663) (in query: SELECT h3GetBaseCell(NULL, NULL);) 2025.06.13 15:41:41.251880 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 2, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:41.452853 [ 8442 ] {22af5902-b55c-4eda-a183-0f6807836dcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 664, line 664) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL);) 2025.06.13 15:41:41.460196 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:41.748326 [ 8442 ] {5fa7c739-b067-41c1-a6fd-51fcf8565b9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 2, should be 1: In scope SELECT h3GetFaces(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 665, line 665) (in query: SELECT h3GetFaces(NULL, NULL);) 2025.06.13 15:41:41.766594 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 2, should be 1: In scope SELECT h3GetFaces(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:41.919610 [ 8442 ] {003b5faf-7927-4b1f-af74-4a5052940780} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 666, line 666) (in query: SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL);) 2025.06.13 15:41:41.942093 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:42.039761 [ 8442 ] {ed828f49-c69c-47da-90fe-f2731de788bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 667, line 667) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL);) 2025.06.13 15:41:42.055983 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:42.060359 [ 3931 ] {0d9b6649-5b6d-4cdd-8792-4f2123a15559} executeQuery: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1570, line 1573) (in query: SELECT variantElement(NULL, NULL);) 2025.06.13 15:41:42.071776 [ 3931 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:42.138197 [ 3931 ] {dd38fb15-0857-4077-bc21-efb279d381af} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 2, should be 1: In scope SELECT variantType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1571, line 1574) (in query: SELECT variantType(NULL, NULL);) 2025.06.13 15:41:42.155193 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 2, should be 1: In scope SELECT variantType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:42.176395 [ 3246 ] {} test_3.replicated_numbers (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:41:42.184887 [ 3225 ] {} test_13.enum_alter_issue (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:41:42.194575 [ 3277 ] {} test_13.sample_table_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:41:42.215557 [ 3244 ] {} test_e3ecl9wf.test_01640 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:41:42.224737 [ 3272 ] {} test_9.replicated_report (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:41:42.248982 [ 8442 ] {f0a537c4-f975-4e93-8282-d75367ec1efd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 2, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 668, line 668) (in query: SELECT h3GetPentagonIndexes(NULL, NULL);) 2025.06.13 15:41:42.282689 [ 3227 ] {} test_11jn31ss.quorum1 (a8279faa-ad54-440e-803d-5674ed97eda3): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:42.282809 [ 3264 ] {} test_41tvivz0.minmax_idx_r (ff91b09c-5c1c-4d9a-a9d1-ea8f88ee1433): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:42.283022 [ 3275 ] {} test_41tvivz0.minmax_idx (4fb2389c-301d-4b1c-884f-effa48f565cf): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:42.283471 [ 3297 ] {} test_2gl1zqnb.replace_partition_dest1 (647528ae-8183-4b55-ba17-9285bdc032ab): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:42.283979 [ 3241 ] {} test_7.x1 (ec6e5a17-17a3-4d9e-a30a-f5a834e37cfd): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:42.284061 [ 3284 ] {} test_zcudb9ph.quorum2 (1ec4565a-906f-49a4-ac6f-be7632a2e587): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:42.284119 [ 3233 ] {} test_zcudb9ph.quorum1 (7304807e-82d5-4c68-839d-2e5bd989e502): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:42.284083 [ 3198 ] {} test_11jn31ss.quorum2 (19dea5dd-4a89-4fe2-a759-66c342de6641): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:42.365071 [ 3710 ] {} DatabaseCatalog: Cannot drop table test_e3ecl9wf.restore_01640 (0a42497e-99d6-47f9-83de-eec111ae32f0). Will retry later.: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1460: Coordination::ZooKeeper::removeRecursive(String const&, unsigned int, std::function) @ 0x000000003281fbb9 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1001: zkutil::ZooKeeper::tryRemoveRecursive(String const&, unsigned int) @ 0x000000003276081f 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1575: DB::StorageReplicatedMergeTree::removeTableNodesFromZooKeeper(std::shared_ptr, DB::TableZnodeInfo const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000305a838d 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1510: DB::StorageReplicatedMergeTree::dropReplica(std::shared_ptr, DB::TableZnodeInfo const&, std::shared_ptr, std::shared_ptr, std::optional*) @ 0x00000000305b8a62 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1382: DB::StorageReplicatedMergeTree::drop() @ 0x00000000305b363a 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d5f99b1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d607d44 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:42.372934 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 2, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:42.596474 [ 8442 ] {e685d892-4f40-48ae-a664-f8366296f681} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 2, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 669, line 669) (in query: SELECT h3GetRes0Indexes(NULL, NULL);) 2025.06.13 15:41:42.617715 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 2, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:42.742811 [ 5112 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:42.839246 [ 8442 ] {c97bbba7-ada9-42a0-8035-3abec932f015} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 2, should be 1: In scope SELECT h3GetResolution(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 670, line 670) (in query: SELECT h3GetResolution(NULL, NULL);) 2025.06.13 15:41:42.863856 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 2, should be 1: In scope SELECT h3GetResolution(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:43.063489 [ 3931 ] {ee948e34-4355-4814-add8-720f778c8357} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 2, should be 0: In scope SELECT version(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1574, line 1577) (in query: SELECT version(NULL, NULL);) 2025.06.13 15:41:43.100956 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 2, should be 0: In scope SELECT version(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:43.185678 [ 5112 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:43.317592 [ 3931 ] {1a906ec7-5955-4918-afc4-fefaa00bd7ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 2, should be 1: In scope SELECT visibleWidth(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1575, line 1578) (in query: SELECT visibleWidth(NULL, NULL);) 2025.06.13 15:41:43.344466 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 2, should be 1: In scope SELECT visibleWidth(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:43.361580 [ 8442 ] {10480686-0089-4d77-813c-bf1d0fe73ca2} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 672, line 672) (in query: SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL);) 2025.06.13 15:41:43.376547 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:43.481110 [ 8442 ] {c30a8900-7181-4186-b6c8-94262ca33279} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 673, line 673) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL);) 2025.06.13 15:41:43.526836 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:43.627109 [ 8442 ] {3c790748-b163-4d2f-858f-a01b8df1381a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 674, line 674) (in query: SELECT h3HexAreaKm2(NULL, NULL);) 2025.06.13 15:41:43.634201 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:43.735420 [ 8442 ] {060e0e5b-2d07-4b0c-aa49-1330d044cc49} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 675, line 675) (in query: SELECT h3HexAreaM2(NULL, NULL);) 2025.06.13 15:41:43.758831 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:44.480960 [ 8442 ] {f2283904-c4c9-40f8-b87a-1e26bf08ee7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 2, should be 1: In scope SELECT h3IsPentagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 678, line 678) (in query: SELECT h3IsPentagon(NULL, NULL);) 2025.06.13 15:41:44.518015 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 2, should be 1: In scope SELECT h3IsPentagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:44.974439 [ 8442 ] {984b5ef9-9f71-4deb-9485-9820e84bcc09} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 2, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 679, line 679) (in query: SELECT h3IsResClassIII(NULL, NULL);) 2025.06.13 15:41:44.999997 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 2, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:45.295022 [ 8442 ] {83d45b03-f807-4052-93aa-07f0adf0564c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 2, should be 1: In scope SELECT h3IsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 680, line 680) (in query: SELECT h3IsValid(NULL, NULL);) 2025.06.13 15:41:45.384169 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 2, should be 1: In scope SELECT h3IsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:45.721671 [ 8442 ] {92d10117-378b-4808-a425-b7b606ae9f8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 2, should be 1: In scope SELECT h3NumHexagons(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 682, line 682) (in query: SELECT h3NumHexagons(NULL, NULL);) 2025.06.13 15:41:45.727755 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 2, should be 1: In scope SELECT h3NumHexagons(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:45.913921 [ 8442 ] {1d57ada7-9424-4066-b4d9-f0d8f448937b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 2, should be 4: In scope SELECT h3PointDistKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 683, line 683) (in query: SELECT h3PointDistKm(NULL, NULL);) 2025.06.13 15:41:45.954911 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 2, should be 4: In scope SELECT h3PointDistKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:45.966334 [ 3931 ] {453b04f4-a5a1-4960-b2d8-7d93f5258072} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT widthBucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1585, line 1588) (in query: SELECT widthBucket(NULL, NULL);) 2025.06.13 15:41:46.041460 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT widthBucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:46.061859 [ 8442 ] {9d3f6758-a35b-4766-8a08-15888c1ee717} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 2, should be 4: In scope SELECT h3PointDistM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 684, line 684) (in query: SELECT h3PointDistM(NULL, NULL);) 2025.06.13 15:41:46.075392 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 2, should be 4: In scope SELECT h3PointDistM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:46.141253 [ 3931 ] {48f8b6d1-46e8-43a0-b70b-8d23690c1d56} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT width_bucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1586, line 1589) (in query: SELECT width_bucket(NULL, NULL);) 2025.06.13 15:41:46.152678 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT width_bucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:46.219827 [ 8442 ] {8b8e4a3f-9d71-4d59-86f6-fb3a4a27ad7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 2, should be 4: In scope SELECT h3PointDistRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 685, line 685) (in query: SELECT h3PointDistRads(NULL, NULL);) 2025.06.13 15:41:46.247857 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 2, should be 4: In scope SELECT h3PointDistRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:47.065874 [ 3931 ] {1c78a120-54d5-4d38-a52a-a21c922ae2ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 2, should be 1: In scope SELECT wkt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1589, line 1592) (in query: SELECT wkt(NULL, NULL);) 2025.06.13 15:41:47.083212 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 2, should be 1: In scope SELECT wkt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:47.249954 [ 8442 ] {b36d9b8b-df5e-4eb4-976d-8401b6041c76} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 2, should be 1: In scope SELECT h3ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 688, line 688) (in query: SELECT h3ToGeo(NULL, NULL);) 2025.06.13 15:41:47.257095 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 2, should be 1: In scope SELECT h3ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:47.342558 [ 8432 ] {839b884e-43b2-4db0-8b7c-4bc72b3b3784} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58702) (comment: 01018_ddl_dictionaries_special.sql) (query 31, line 104) (in query: DROP DATABASE IF EXISTS test_11), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:41:47.397250 [ 8432 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:41:47.476834 [ 8442 ] {b7add610-53d4-4276-9a2e-db2fd32c1ba4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 2, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 689, line 689) (in query: SELECT h3ToGeoBoundary(NULL, NULL);) 2025.06.13 15:41:47.502581 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 2, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:47.999846 [ 8442 ] {17e95a07-8042-4105-aca1-2c6bb6046571} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 2, should be 1: In scope SELECT h3ToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 691, line 691) (in query: SELECT h3ToString(NULL, NULL);) 2025.06.13 15:41:48.027401 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 2, should be 1: In scope SELECT h3ToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:48.231548 [ 8442 ] {2d6518f0-e30e-4c03-add4-c37b80052f3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 2, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 692, line 692) (in query: SELECT h3UnidirectionalEdgeIsValid(NULL, NULL);) 2025.06.13 15:41:48.256789 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 2, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:48.561548 [ 4098 ] {c4fc6ec4-2976-4791-a1b4-bbf48a20d6ae} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42378) (comment: 01083_aggregation_memory_efficient_bug.sql) (query 2, line 2) (in query: CREATE TABLE da_memory_efficient_shard (`A` Int64, `B` Int64) ENGINE = MergeTree PARTITION BY B % 2 ORDER BY A SETTINGS index_granularity = 62960, min_bytes_for_wide_part = 114094832, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 112, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 125941337, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 3975002, merge_max_block_size = 5382, old_parts_lifetime = 103., 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 = 15402152, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 35, 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 = 15271, primary_key_compress_block_size = 97285, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:41:48.576312 [ 4098 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:41:48.916280 [ 8442 ] {f69774b1-1396-4496-b989-29a375f2ac9b} executeQuery: Code: 43. DB::Exception: First argument for function has must be an array or map. Actual Nullable(Nothing): In scope SELECT has(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 695, line 695) (in query: SELECT has(NULL, NULL);) 2025.06.13 15:41:48.935971 [ 9636 ] {e800201c-bbb8-4ed7-ba05-eda8e4d9164a} executeQuery: Code: 60. DB::Exception: Table test_3.t1_02867 does not exist. Maybe you meant test_9.t1_02867?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42568) (comment: 02867_storage_set_tsan.sh) (query 1, line 1) (in query: TRUNCATE t1_02867;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:41:48.941878 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function has must be an array or map. Actual Nullable(Nothing): In scope SELECT has(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:48.941948 [ 8432 ] {53b69878-8410-4ab2-962f-fdf3f71af30e} executeQuery: Code: 60. DB::Exception: Table test_3.t1_02867 does not exist. Maybe you meant test_9.t1_02867?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42576) (comment: 02867_storage_set_tsan.sh) (query 1, line 1) (in query: TRUNCATE t1_02867;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:41:48.960366 [ 8432 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3.t1_02867 does not exist. Maybe you meant test_9.t1_02867?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:41:49.016697 [ 8101 ] {6f236025-a59f-4c9b-9c82-1ad64b2a34da} executeQuery: Code: 47. DB::Exception: Unknown expression or table expression identifier `t1_02867` in scope SELECT count() AS a FROM numbers(10) WHERE number IN (t1_02867). (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42558) (comment: 02867_storage_set_tsan.sh) (query 1, line 1) (in query: SELECT count() as a FROM numbers(10) WHERE number IN t1_02867), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:41:49.018905 [ 9636 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3.t1_02867 does not exist. Maybe you meant test_9.t1_02867?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:41:49.042425 [ 8101 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or table expression identifier `t1_02867` in scope SELECT count() AS a FROM numbers(10) WHERE number IN (t1_02867). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:41:49.048076 [ 8430 ] {ee19ba5a-3c91-44aa-a6ac-1233e9679268} executeQuery: Code: 47. DB::Exception: Unknown expression or table expression identifier `t1_02867` in scope SELECT count() AS a FROM numbers(10) WHERE number IN (t1_02867). (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42582) (comment: 02867_storage_set_tsan.sh) (query 1, line 1) (in query: SELECT count() as a FROM numbers(10) WHERE number IN t1_02867), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:41:49.064469 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or table expression identifier `t1_02867` in scope SELECT count() AS a FROM numbers(10) WHERE number IN (t1_02867). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:41:49.141213 [ 8099 ] {575e42f9-32e1-49a3-8a57-5c9afbae00e8} executeQuery: Code: 60. DB::Exception: Table test_3.t1_02867 does not exist. Maybe you meant test_9.t1_02867?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42618) (comment: 02867_storage_set_tsan.sh) (query 1, line 1) (in query: TRUNCATE t1_02867;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:41:49.168396 [ 8099 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3.t1_02867 does not exist. Maybe you meant test_9.t1_02867?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:41:49.349844 [ 7755 ] {f2007567-e4e3-42e1-b01e-2be533df0c03} executeQuery: Code: 47. DB::Exception: Unknown expression or table expression identifier `t1_02867` in scope SELECT count() AS a FROM numbers(10) WHERE number IN (t1_02867). (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42640) (comment: 02867_storage_set_tsan.sh) (query 1, line 1) (in query: SELECT count() as a FROM numbers(10) WHERE number IN t1_02867), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:41:49.364085 [ 8101 ] {9fcbda2d-0b24-4603-a5dc-a48b288b5195} executeQuery: Code: 47. DB::Exception: Unknown expression or table expression identifier `t1_02867` in scope SELECT count() AS a FROM numbers(10) WHERE number IN (t1_02867). (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42660) (comment: 02867_storage_set_tsan.sh) (query 1, line 1) (in query: SELECT count() as a FROM numbers(10) WHERE number IN t1_02867), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:41:49.375859 [ 8432 ] {970168a8-3c8f-447d-a206-8b04784ee3d7} executeQuery: Code: 60. DB::Exception: Table test_3.t1_02867 does not exist. Maybe you meant test_9.t1_02867?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42632) (comment: 02867_storage_set_tsan.sh) (query 1, line 1) (in query: TRUNCATE t1_02867;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:41:49.396938 [ 8101 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or table expression identifier `t1_02867` in scope SELECT count() AS a FROM numbers(10) WHERE number IN (t1_02867). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:41:49.398070 [ 7755 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or table expression identifier `t1_02867` in scope SELECT count() AS a FROM numbers(10) WHERE number IN (t1_02867). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:41:49.409085 [ 8432 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3.t1_02867 does not exist. Maybe you meant test_9.t1_02867?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:41:50.496263 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:50.655576 [ 8442 ] {27df2576-ec7b-45ff-8089-e8121e1d92a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 2, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 704, line 704) (in query: SELECT hasThreadFuzzer(NULL, NULL);) 2025.06.13 15:41:50.670935 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 2, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:50.947981 [ 8430 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:51.329827 [ 9642 ] {755e52e5-d29c-4010-9731-3aa50085003d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38736) (comment: 02932_parallel_replicas_fuzzer.sql) (in query: DROP DATABASE IF EXISTS test_eeas2yro SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:41:51.334333 [ 9642 ] {755e52e5-d29c-4010-9731-3aa50085003d} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:51.369949 [ 3931 ] {0c33927b-d236-460d-b4ae-5a0e5e006781} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 2, should be 0: In scope SELECT yesterday(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1609, line 1612) (in query: SELECT yesterday(NULL, NULL);) 2025.06.13 15:41:51.384913 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 2, should be 0: In scope SELECT yesterday(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:51.471987 [ 3931 ] {f170f688-86a5-412b-afd6-30e77f0157cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 2, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40434) (comment: 00534_functions_bad_arguments8.sh) (query 1610, line 1613) (in query: SELECT zookeeperSessionUptime(NULL, NULL);) 2025.06.13 15:41:51.505575 [ 3931 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 2, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:51.507300 [ 7755 ] {4b8f78a3-8c62-4d43-a267-9b65e3ad1f2c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38746) (comment: 02932_parallel_replicas_fuzzer.sql) (in query: DROP DATABASE IF EXISTS test_eeas2yro SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:41:51.534500 [ 7755 ] {4b8f78a3-8c62-4d43-a267-9b65e3ad1f2c} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:51.752440 [ 8442 ] {df952893-05a8-4bca-bd34-02778c43e719} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 2, should be 1: In scope SELECT hex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 709, line 709) (in query: SELECT hex(NULL, NULL);) 2025.06.13 15:41:51.822390 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 2, should be 1: In scope SELECT hex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:52.236635 [ 9636 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:52.451984 [ 6193 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:52.592894 [ 8431 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:52.940672 [ 8431 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:53.163252 [ 8431 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:53.379586 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:53.497562 [ 8431 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:53.528251 [ 8442 ] {72514343-16fe-4256-8210-93fa205c7872} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 717, line 717) (in query: SELECT hostName(NULL, NULL);) 2025.06.13 15:41:53.546650 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:53.639854 [ 18510 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:53.686156 [ 8442 ] {6c750b9e-fa7d-4496-bd7b-663226bdf213} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostname(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 718, line 718) (in query: SELECT hostname(NULL, NULL);) 2025.06.13 15:41:53.698136 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostname(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:53.769822 [ 18510 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:53.906874 [ 8432 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:54.152967 [ 5978 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:54.174093 [ 3931 ] {f94bfca4-77e2-4a2a-936e-40bd1c726f45} 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.20286.altinityantalya (altinity build)) (from [::1]:38718) (comment: 02265_column_ttl.sql) (query 3, line 9) (in query: CREATE TABLE ttl_02265 (`date` Date, `key` Int, `value` String TTL date + toIntervalMonth(1)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/ttl_02265', 'r1') PARTITION BY date ORDER BY key SETTINGS min_bytes_for_wide_part = 0, index_granularity = 6190, 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 = 403839507, compact_parts_max_bytes_to_buffer = 217174478, compact_parts_max_granules_to_buffer = 252, compact_parts_merge_max_bytes_to_prefetch_part = 1710132, merge_max_block_size = 18874, old_parts_lifetime = 365., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 25865597, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 57, 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 = 59190, primary_key_compress_block_size = 29432, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:41:54.180892 [ 3931 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:41:54.207399 [ 8442 ] {064f466d-d9ca-48c5-ba37-a1865864d5fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergHash doesn't match: passed 2, should be 1: In scope SELECT icebergHash(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 721, line 721) (in query: SELECT icebergHash(NULL, NULL);) 2025.06.13 15:41:54.220586 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergHash doesn't match: passed 2, should be 1: In scope SELECT icebergHash(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:54.295527 [ 8430 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:54.404308 [ 3931 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:54.446448 [ 8442 ] {c64b6aae-2ab2-4086-98fb-b9a1db4af5ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 2, should be 1: In scope SELECT identity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 723, line 723) (in query: SELECT identity(NULL, NULL);) 2025.06.13 15:41:54.459454 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 2, should be 1: In scope SELECT identity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:54.566027 [ 3931 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:54.580996 [ 8442 ] {7857c687-e039-4844-be3c-63e05da72f78} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 2, should be 1: In scope SELECT idnaDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 724, line 724) (in query: SELECT idnaDecode(NULL, NULL);) 2025.06.13 15:41:54.592621 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 2, should be 1: In scope SELECT idnaDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:54.684190 [ 3931 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:54.688353 [ 8442 ] {5cb8dbf5-3f2c-402c-a6d4-e2ef8b0f404c} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 2, should be 1: In scope SELECT idnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 725, line 725) (in query: SELECT idnaEncode(NULL, NULL);) 2025.06.13 15:41:54.710522 [ 8101 ] {5cc12095-cbb8-4db8-a39f-9f53821a3dd1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38760) (comment: 02867_storage_set_tsan.sh) (query 1, line 1) (in query: SELECT count() as a FROM numbers(10) WHERE number IN t1_02867), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:41:54.711480 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 2, should be 1: In scope SELECT idnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:54.736200 [ 8101 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:41:54.802931 [ 8432 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:54.825312 [ 8442 ] {4b8b8545-38fa-40d1-bbda-138708266e50} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 2, should be 3: In scope SELECT if(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 726, line 726) (in query: SELECT if(NULL, NULL);) 2025.06.13 15:41:54.836433 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 2, should be 3: In scope SELECT if(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:54.923702 [ 5978 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:55.075560 [ 5978 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:55.220937 [ 5978 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:55.638957 [ 3931 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:55.830695 [ 6234 ] {83b3dc15-20f0-406e-a47f-39e9c19d5128} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59156) (comment: 00872_t64_bit_codec.sql) (query 30, line 46) (in query: SELECT * FROM t64 WHERE u64 != t_u64;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:41:55.869216 [ 6234 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:41:55.910144 [ 8442 ] {31959d16-3733-4886-adb7-21c910a4c401} executeQuery: Code: 43. DB::Exception: First argument for function indexOf must be an array. Actual Nullable(Nothing): In scope SELECT indexOf(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 734, line 734) (in query: SELECT indexOf(NULL, NULL);) 2025.06.13 15:41:55.918464 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function indexOf must be an array. Actual Nullable(Nothing): In scope SELECT indexOf(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:55.991907 [ 8442 ] {eb9f34e1-a357-4f2f-9367-d7ee836c2f8f} executeQuery: Code: 43. DB::Exception: First argument for function indexOfAssumeSorted must be an array. Actual Nullable(Nothing): In scope SELECT indexOfAssumeSorted(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 735, line 735) (in query: SELECT indexOfAssumeSorted(NULL, NULL);) 2025.06.13 15:41:55.998548 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function indexOfAssumeSorted must be an array. Actual Nullable(Nothing): In scope SELECT indexOfAssumeSorted(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:56.078265 [ 7755 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:56.083568 [ 8442 ] {dcb49135-3040-471f-9099-c5dfbeb0ba6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 2, should be 1: In scope SELECT initcap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 736, line 736) (in query: SELECT initcap(NULL, NULL);) 2025.06.13 15:41:56.102261 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 2, should be 1: In scope SELECT initcap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:56.296320 [ 8442 ] {8d02e9d6-bdf1-4288-bdeb-f091136a0863} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 2, should be 1: In scope SELECT initcapUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 737, line 737) (in query: SELECT initcapUTF8(NULL, NULL);) 2025.06.13 15:41:56.352967 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 2, should be 1: In scope SELECT initcapUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:56.446393 [ 8442 ] {684909ef-1edc-400a-86bd-555b1a25fe51} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initialQueryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 738, line 738) (in query: SELECT initialQueryID(NULL, NULL);) 2025.06.13 15:41:56.457637 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initialQueryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:56.520886 [ 8442 ] {51646731-4d1e-430d-b88a-b389735f5aba} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 2, should be 0: In scope SELECT initialQueryStartTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 739, line 739) (in query: SELECT initialQueryStartTime(NULL, NULL);) 2025.06.13 15:41:56.530375 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 2, should be 0: In scope SELECT initialQueryStartTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:56.585676 [ 3931 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:56.632311 [ 8442 ] {8e59d95e-2f14-4941-9130-37ba2477fed6} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initial_query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 740, line 740) (in query: SELECT initial_query_id(NULL, NULL);) 2025.06.13 15:41:56.679760 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initial_query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:56.735538 [ 8442 ] {9d6019ae-0602-4323-ad89-a65d6746dbae} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 2, should be 0: In scope SELECT initial_query_start_time(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 741, line 741) (in query: SELECT initial_query_start_time(NULL, NULL);) 2025.06.13 15:41:56.765497 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 2, should be 0: In scope SELECT initial_query_start_time(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:56.873111 [ 8442 ] {a57b278b-e9e1-4d66-b2ad-cd320f0e6151} executeQuery: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 742, line 742) (in query: SELECT initializeAggregation(NULL, NULL);) 2025.06.13 15:41:56.881095 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:56.901124 [ 3931 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:57.207248 [ 7755 ] {78a6fea1-b3b1-415b-91f3-b67b8bccc411} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38828) (comment: 02896_illegal_sampling.sql) (query 1, line 1) (in query: SELECT * FROM (SELECT 1) SAMPLE 1 / 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbac44e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba12bc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:41:57.216989 [ 7755 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildJoinTree(DB::ASTSelectQuery const&, std::shared_ptr const&) const @ 0x000000002cbac44e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:317: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba12bc 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:41:57.526396 [ 8442 ] {15c0a3ca-4fe1-4687-9696-ad84fb6dc76c} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 2, should be 1: In scope SELECT intExp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 746, line 746) (in query: SELECT intExp10(NULL, NULL);) 2025.06.13 15:41:57.548819 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 2, should be 1: In scope SELECT intExp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:57.676990 [ 8442 ] {051d86c4-1e7c-44d5-8f68-6bd104013043} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 2, should be 1: In scope SELECT intExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 747, line 747) (in query: SELECT intExp2(NULL, NULL);) 2025.06.13 15:41:57.704866 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 2, should be 1: In scope SELECT intExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:57.817650 [ 8442 ] {2b063bd5-6156-4d0c-919d-c8bb55b8d84c} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 2, should be 1: In scope SELECT intHash32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 748, line 748) (in query: SELECT intHash32(NULL, NULL);) 2025.06.13 15:41:57.841258 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 2, should be 1: In scope SELECT intHash32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:57.952749 [ 8442 ] {6cdad350-bd8e-43ec-9a39-b77bf9fca6d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 2, should be 1: In scope SELECT intHash64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 749, line 749) (in query: SELECT intHash64(NULL, NULL);) 2025.06.13 15:41:57.969437 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 2, should be 1: In scope SELECT intHash64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:58.274397 [ 8442 ] {9438d1e6-f81d-4af8-83ea-02af1fa0d5b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 2, should be 1: In scope SELECT isConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 751, line 751) (in query: SELECT isConstant(NULL, NULL);) 2025.06.13 15:41:58.284383 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 2, should be 1: In scope SELECT isConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:58.477345 [ 5978 ] {9e3472f3-d574-4880-b1b1-d55d13daab7c} auto DB::FileCache::initialize()::(anonymous class)::operator()() const: Code: 36. DB::Exception: The total capacity of the disk containing cache path /var/lib/clickhouse/filesystem_caches/03324_cache_disk_validation_max_size_test_15_1 is less than the specified max_size 109951162777600 bytes. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/Cache/FileCache.cpp:220: void std::__call_once_proxy[abi:ne190107]>(void*) @ 0x000000002e39ce8a 6. ./build_docker/./contrib/llvm-project/libcxx/src/call_once.cpp:57: std::__call_once(unsigned long volatile&, void*, void (*)(void*)) @ 0x0000000038ef669b 7. ./contrib/llvm-project/libcxx/include/__mutex/once_flag.h:131: DB::FileCache::initialize() @ 0x000000002e382e40 8. ./build_docker/./src/Disks/ObjectStorages/Cached/CachedObjectStorage.cpp:34: DB::CachedObjectStorage::CachedObjectStorage(std::shared_ptr, std::shared_ptr, DB::FileCacheSettings const&, String const&) @ 0x000000002ca0a663 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, DB::FileCacheSettings const&, String const&, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&, DB::FileCacheSettings const&, String const&) @ 0x000000002ca09ec4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::FileCacheSettings const&, String const&, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::FileCacheSettings const&, String const&) @ 0x000000002ca09cce 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DiskObjectStorage::wrapWithCache(std::shared_ptr, DB::FileCacheSettings const&, String const&) @ 0x000000002ca0917a 12. ./build_docker/./src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:120: 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 @ 0x000000002c9a2c49 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 14. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 15. ./build_docker/./src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:ne190107], String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x0000000030fd993c 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d4a40b1 17. ./build_docker/./src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000030fd8323 18. ./build_docker/./src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000030fda5fe 19. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000030fda1cd 20. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030fd9188 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000030f97244 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000030f9b53b 23. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bbd01 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 27. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:58.506375 [ 5978 ] {9e3472f3-d574-4880-b1b1-d55d13daab7c} executeQuery: Code: 36. DB::Exception: The total capacity of the disk containing cache path /var/lib/clickhouse/filesystem_caches/03324_cache_disk_validation_max_size_test_15_1 is less than the specified max_size 109951162777600 bytes: While processing disk(name = '03324_cache_disk_validation_max_size_test_15_1', type = cache, max_size = '100Ti', path = '03324_cache_disk_validation_max_size_test_15_1', disk = s3_disk). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38858) (comment: 03324_cache_disk_validation_max_size.sh) (query 2, line 3) (in query: CREATE TABLE test (`a` Int32, `b` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(name = '03324_cache_disk_validation_max_size_test_15_1', type = cache, max_size = '100Ti', path = '03324_cache_disk_validation_max_size_test_15_1', disk = s3_disk), index_granularity = 55423, 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 = 317466960, compact_parts_max_granules_to_buffer = 238, compact_parts_merge_max_bytes_to_prefetch_part = 12020380, merge_max_block_size = 16670, old_parts_lifetime = 280., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 64082, 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 = 69851, primary_key_compress_block_size = 71210, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/Cache/FileCache.cpp:220: void std::__call_once_proxy[abi:ne190107]>(void*) @ 0x000000002e39ce8a 6. ./build_docker/./contrib/llvm-project/libcxx/src/call_once.cpp:57: std::__call_once(unsigned long volatile&, void*, void (*)(void*)) @ 0x0000000038ef669b 7. ./contrib/llvm-project/libcxx/include/__mutex/once_flag.h:131: DB::FileCache::initialize() @ 0x000000002e382e40 8. ./build_docker/./src/Disks/ObjectStorages/Cached/CachedObjectStorage.cpp:34: DB::CachedObjectStorage::CachedObjectStorage(std::shared_ptr, std::shared_ptr, DB::FileCacheSettings const&, String const&) @ 0x000000002ca0a663 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, DB::FileCacheSettings const&, String const&, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&, DB::FileCacheSettings const&, String const&) @ 0x000000002ca09ec4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::FileCacheSettings const&, String const&, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::FileCacheSettings const&, String const&) @ 0x000000002ca09cce 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DiskObjectStorage::wrapWithCache(std::shared_ptr, DB::FileCacheSettings const&, String const&) @ 0x000000002ca0917a 12. ./build_docker/./src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:120: 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 @ 0x000000002c9a2c49 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 14. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 15. ./build_docker/./src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:ne190107], String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x0000000030fd993c 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d4a40b1 17. ./build_docker/./src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000030fd8323 18. ./build_docker/./src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000030fda5fe 19. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000030fda1cd 20. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030fd9188 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000030f97244 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000030f9b53b 23. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bbd01 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 27. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:41:58.552463 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: The total capacity of the disk containing cache path /var/lib/clickhouse/filesystem_caches/03324_cache_disk_validation_max_size_test_15_1 is less than the specified max_size 109951162777600 bytes: While processing disk(name = '03324_cache_disk_validation_max_size_test_15_1', type = cache, max_size = '100Ti', path = '03324_cache_disk_validation_max_size_test_15_1', disk = s3_disk). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/Cache/FileCache.cpp:220: void std::__call_once_proxy[abi:ne190107]>(void*) @ 0x000000002e39ce8a 6. ./build_docker/./contrib/llvm-project/libcxx/src/call_once.cpp:57: std::__call_once(unsigned long volatile&, void*, void (*)(void*)) @ 0x0000000038ef669b 7. ./contrib/llvm-project/libcxx/include/__mutex/once_flag.h:131: DB::FileCache::initialize() @ 0x000000002e382e40 8. ./build_docker/./src/Disks/ObjectStorages/Cached/CachedObjectStorage.cpp:34: DB::CachedObjectStorage::CachedObjectStorage(std::shared_ptr, std::shared_ptr, DB::FileCacheSettings const&, String const&) @ 0x000000002ca0a663 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, DB::FileCacheSettings const&, String const&, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&, DB::FileCacheSettings const&, String const&) @ 0x000000002ca09ec4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::FileCacheSettings const&, String const&, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::FileCacheSettings const&, String const&) @ 0x000000002ca09cce 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DiskObjectStorage::wrapWithCache(std::shared_ptr, DB::FileCacheSettings const&, String const&) @ 0x000000002ca0917a 12. ./build_docker/./src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:120: 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 @ 0x000000002c9a2c49 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 14. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 15. ./build_docker/./src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:ne190107], String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x0000000030fd993c 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d4a40b1 17. ./build_docker/./src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000030fd8323 18. ./build_docker/./src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000030fda5fe 19. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000030fda1cd 20. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030fd9188 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000030f97244 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000030f9b53b 23. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bbd01 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 27. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:41:58.566406 [ 8442 ] {f86e4ff4-58e8-4d99-b8c1-cc8f90877442} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 2, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 753, line 753) (in query: SELECT isDynamicElementInSharedData(NULL, NULL);) 2025.06.13 15:41:58.612683 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 2, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:58.624682 [ 3506 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4380db44-62cf-49cd-9099-49cbb3c9dd97::202506_56_66_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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab57af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab1fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003122f56b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d8e4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:41:58.749060 [ 8442 ] {dc501c12-a28f-4ba7-af00-34bc4a1b5427} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 2, should be 1: In scope SELECT isFinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 754, line 754) (in query: SELECT isFinite(NULL, NULL);) 2025.06.13 15:41:58.766313 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 2, should be 1: In scope SELECT isFinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:58.964206 [ 8442 ] {272a3c14-2038-4984-9824-df227e6d0966} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 755, line 755) (in query: SELECT isIPAddressInRange(NULL, NULL);) 2025.06.13 15:41:59.011553 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:41:59.135937 [ 8442 ] {a744e006-c6db-4582-9e83-121b8d96dda8} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 2, should be 1: In scope SELECT isIPv4String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 756, line 756) (in query: SELECT isIPv4String(NULL, NULL);) 2025.06.13 15:41:59.146468 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 2, should be 1: In scope SELECT isIPv4String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:59.239891 [ 8442 ] {c3192fe7-c225-4774-a8d2-f94162c23dff} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 2, should be 1: In scope SELECT isIPv6String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 757, line 757) (in query: SELECT isIPv6String(NULL, NULL);) 2025.06.13 15:41:59.253029 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 2, should be 1: In scope SELECT isIPv6String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:59.339824 [ 8442 ] {2c00c730-cb84-4b81-a067-de919117180e} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 2, should be 1: In scope SELECT isInfinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 758, line 758) (in query: SELECT isInfinite(NULL, NULL);) 2025.06.13 15:41:59.351487 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 2, should be 1: In scope SELECT isInfinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:59.456920 [ 8442 ] {eba809b7-9241-424e-8c99-a85d8ead9a14} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 2, should be 1: In scope SELECT isNaN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 759, line 759) (in query: SELECT isNaN(NULL, NULL);) 2025.06.13 15:41:59.477681 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 2, should be 1: In scope SELECT isNaN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:59.591083 [ 8442 ] {c274c11b-9505-48a8-871f-32b4bcd70beb} executeQuery: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section: In scope SELECT NULL <=> NULL. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 760, line 760) (in query: SELECT isNotDistinctFrom(NULL, NULL);) 2025.06.13 15:41:59.604037 [ 8442 ] {} TCPHandler: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section: In scope SELECT NULL <=> NULL. (NOT_IMPLEMENTED) 2025.06.13 15:41:59.682534 [ 8442 ] {7482154b-3f39-4143-b4fb-7ac3083d47c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 2, should be 1: In scope SELECT isNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 761, line 761) (in query: SELECT isNotNull(NULL, NULL);) 2025.06.13 15:41:59.692272 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 2, should be 1: In scope SELECT isNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:59.771056 [ 8442 ] {a5ef6f40-7f97-44e2-bffe-2495a730514c} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 2, should be 1: In scope SELECT isNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 762, line 762) (in query: SELECT isNull(NULL, NULL);) 2025.06.13 15:41:59.785216 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 2, should be 1: In scope SELECT isNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:41:59.946720 [ 8442 ] {53d7a5a4-0bea-423e-a8e0-842c0a547fd4} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 2, should be 1: In scope SELECT isNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 763, line 763) (in query: SELECT isNullable(NULL, NULL);) 2025.06.13 15:41:59.964623 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 2, should be 1: In scope SELECT isNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:00.085661 [ 8442 ] {ec15b3ed-d49d-403c-8623-c7e7a51ee603} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 764, line 764) (in query: SELECT isValidJSON(NULL, NULL);) 2025.06.13 15:42:00.120586 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:00.306224 [ 8442 ] {14402bd2-4790-448d-8465-cbc78cb417ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT isValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 765, line 765) (in query: SELECT isValidUTF8(NULL, NULL);) 2025.06.13 15:42:00.325726 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT isValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:00.444523 [ 8442 ] {83801499-65a0-4d15-98f9-63792cd7a9ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 2, should be 1: In scope SELECT isZeroOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 766, line 766) (in query: SELECT isZeroOrNull(NULL, NULL);) 2025.06.13 15:42:00.476466 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 2, should be 1: In scope SELECT isZeroOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:00.607068 [ 7755 ] {cb7d1933-2b7d-4b9d-ac53-55ee9e395957} 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.20286.altinityantalya (altinity build)) (from [::1]:38952) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04442f 5. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x000000002c4c2f61 6. std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const @ 0x000000002afe0e4c 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002afe0886 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:42:00.688338 [ 7755 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04442f 5. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x000000002c4c2f61 6. std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const @ 0x000000002afe0e4c 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createStringToEnumWrapper>() const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002afe0886 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:42:01.424087 [ 8442 ] {8e026ada-50c0-47a8-9367-cc789ef91da6} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 771, line 771) (in query: SELECT joinGet(NULL, NULL);) 2025.06.13 15:42:01.437966 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:01.466717 [ 8430 ] {da3fa8df-025d-485d-96d8-1a29aa63772f} executeQuery: Code: 57. DB::Exception: Table test_15.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38994) (comment: 03314_analyzer_resolve_in_parent_scope_2.sql) (query 1, line 1) (in query: CREATE TABLE test (`raw_id` String, `columns_n` Nested(col_1 Nullable(String), col_2 Nullable(String))) ENGINE = MergeTree ORDER BY raw_id SETTINGS index_granularity = 38065, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.6745824217796326, replace_long_file_name_to_hash = true, max_file_name_length = 124, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 47226691, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 21295581, merge_max_block_size = 4330, old_parts_lifetime = 96., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 91, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 1299308, 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 = true, marks_compress_block_size = 98514, primary_key_compress_block_size = 27034, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:42:01.485282 [ 8430 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:42:01.536720 [ 8442 ] {d6d0861d-8a60-414d-878d-edc25a8f35cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 772, line 772) (in query: SELECT joinGetOrNull(NULL, NULL);) 2025.06.13 15:42:01.545080 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:02.357968 [ 8442 ] {ba4f684a-cd99-4d1b-9294-2d3e4fec9ad3} executeQuery: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 2, should be 1: In scope SELECT keccak256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 776, line 776) (in query: SELECT keccak256(NULL, NULL);) 2025.06.13 15:42:02.368279 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 2, should be 1: In scope SELECT keccak256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:02.506206 [ 8430 ] {efdcdf0c-f876-4cd3-a1d4-6155e996f3cf} executeQuery: Code: 6. DB::Exception: Cannot parse string '2019-09-16 19:20:12.3456789102019-09-16 19:20:12.345678910' as DateTime64(0): syntax error at position 33 (parsed just '2019-09-16 19:20:12.3456789102019'): In scope WITH toDateTime64('2019-09-16 19:20:12.3456789102019-09-16 19:20:12.345678910', 0) AS dt64 SELECT dt64. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 1, line 1) (in query: WITH toDateTime64('2019-09-16 19:20:12.3456789102019-09-16 19:20:12.345678910', 0) AS dt64 SELECT dt64;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1c67b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1d936 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:42:02.546100 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2019-09-16 19:20:12.3456789102019-09-16 19:20:12.345678910' as DateTime64(0): syntax error at position 33 (parsed just '2019-09-16 19:20:12.3456789102019'): In scope WITH toDateTime64('2019-09-16 19:20:12.3456789102019-09-16 19:20:12.345678910', 0) AS dt64 SELECT dt64. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1c67b 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1d936 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:42:02.917612 [ 8430 ] {2a469bd9-33fe-451c-b564-d2bdf38c2ed9} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-12345678901234567890' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-12345678901234567890', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 3, line 4) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-12345678901234567890', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:02.928016 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-12345678901234567890' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-12345678901234567890', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:03.546486 [ 2860 ] {fcbb5135-364b-428e-ab56-152307bb8c0b} executeQuery: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39050) (comment: 02695_storage_join_insert_select_deadlock.sql) (query 4, line 11) (in query: INSERT INTO test_table_join SELECT * from test_table_join;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:329: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x000000003043caeb 6. ./build_docker/./src/Storages/StorageSet.cpp:107: DB::SetOrJoinSink::consume(DB::Chunk&) @ 0x0000000030777f90 7. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f67cf7 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:42:03.562891 [ 2860 ] {} TCPHandler: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:329: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x000000003043caeb 6. ./build_docker/./src/Storages/StorageSet.cpp:107: DB::SetOrJoinSink::consume(DB::Chunk&) @ 0x0000000030777f90 7. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f67cf7 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:42:03.678684 [ 8442 ] {63bf36f2-838c-46b4-a095-bb7e6d214866} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 783, line 783) (in query: SELECT lagInFrame(NULL, NULL);) 2025.06.13 15:42:03.687812 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:03.716569 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.13 15:42:03.841842 [ 2860 ] {50d21449-2784-423a-a8fe-4edffe835324} executeQuery: Code: 264. DB::Exception: Table test_nvz8jaqj.test_table_join (b86f17a1-1142-4315-b8a6-381f969548a6) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39050) (comment: 02695_storage_join_insert_select_deadlock.sql) (query 5, line 13) (in query: INSERT INTO test_table_join SELECT * FROM (SELECT 1 as id) AS t1 ANY LEFT JOIN test_table_join USING (id);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/StorageJoin.cpp:248: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x000000003043bffb 6. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf3bd0 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213d4c9 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:579: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dce087d 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5edc 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:42:03.847522 [ 2860 ] {} TCPHandler: Code: 264. DB::Exception: Table test_nvz8jaqj.test_table_join (b86f17a1-1142-4315-b8a6-381f969548a6) 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/StorageJoin.cpp:248: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x000000003043bffb 6. ./build_docker/./src/Planner/PlannerJoins.cpp:1244: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf3bd0 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213d4c9 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:579: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dce087d 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5edc 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:42:03.924952 [ 8431 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:04.018527 [ 18381 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:04.041916 [ 8442 ] {ea2a31e8-1185-44f2-85f6-5c9f5f878ac2} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 785, line 785) (in query: SELECT lastValueRespectNulls(NULL, NULL);) 2025.06.13 15:42:04.045419 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:04.052066 [ 2860 ] {aa2e1fca-cfb6-494c-9aa7-ab9899063c34} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42308) (comment: 02695_storage_join_insert_select_deadlock.sql) (in query: DROP DATABASE IF EXISTS test_nvz8jaqj SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:42:04.054866 [ 2860 ] {aa2e1fca-cfb6-494c-9aa7-ab9899063c34} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:04.077573 [ 8431 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:04.211901 [ 2860 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:04.293059 [ 8442 ] {5b04f909-47dc-43a9-bc39-cd5ee2e310ac} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 787, line 787) (in query: SELECT last_value_respect_nulls(NULL, NULL);) 2025.06.13 15:42:04.299775 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:04.299873 [ 8431 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:04.427393 [ 8442 ] {2bf4497b-6b83-4ef5-8b76-5b23ad043d50} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lcase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 788, line 788) (in query: SELECT lcase(NULL, NULL);) 2025.06.13 15:42:04.436542 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:04.440655 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lcase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:04.730579 [ 8442 ] {712e972a-df55-4aec-9efb-27d865d14ec4} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 790, line 790) (in query: SELECT leadInFrame(NULL, NULL);) 2025.06.13 15:42:04.741082 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.13 15:42:04.854210 [ 18381 ] {849ee1d7-9f92-4325-b197-e2b5ba9ec186} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54862) (comment: 03270_object_to_json_alter_memory.sql) (query 1, line 3) (in query: set allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:42:04.856237 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:04.881364 [ 18381 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:42:05.394205 [ 18381 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:05.908507 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:05.919248 [ 8442 ] {7ea8ba89-34b4-48be-91c3-19db03698f58} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 796, line 796) (in query: SELECT lemmatize(NULL, NULL);) 2025.06.13 15:42:05.929047 [ 8442 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:42:06.009929 [ 8442 ] {e63a8c96-d79e-4f9e-a08e-6faeef1d3501} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT length(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 797, line 797) (in query: SELECT length(NULL, NULL);) 2025.06.13 15:42:06.028733 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT length(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:06.104812 [ 8442 ] {778d0cb6-d043-4e0f-935b-5f80f13fadd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT lengthUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 798, line 798) (in query: SELECT lengthUTF8(NULL, NULL);) 2025.06.13 15:42:06.111409 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT lengthUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:06.193006 [ 2860 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:06.609912 [ 2860 ] {2d8ccd6b-3aab-40d1-a99a-90bc397777cd} executeQuery: Code: 57. DB::Exception: Table test_15.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54890) (comment: 02597_projection_materialize_and_replication.sql) (query 1, line 1) (in query: CREATE TABLE test (`c_id` String, `p_id` String, `d` String) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test/test_table', '1') ORDER BY (c_id, p_id) SETTINGS index_granularity = 21823, min_bytes_for_wide_part = 31433685, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 50, min_bytes_for_full_part_storage = 232922984, compact_parts_max_bytes_to_buffer = 220341851, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 28132534, merge_max_block_size = 656, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 41, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 23144273, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 32, 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 = 59882, primary_key_compress_block_size = 94520, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:42:06.615040 [ 2860 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:42:06.847011 [ 8430 ] {9f5d331f-ac04-403c-9c5a-f662d51ed1d7} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 25, line 29) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-1', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:06.915948 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:06.916394 [ 8442 ] {ad9b9fb8-eb92-41cf-bfb5-6631002ec723} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 2, should be 1: In scope SELECT lgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 803, line 803) (in query: SELECT lgamma(NULL, NULL);) 2025.06.13 15:42:06.931876 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 2, should be 1: In scope SELECT lgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:07.014164 [ 8430 ] {f2cb26e0-cd30-4165-ba3f-3e2a8979b0a7} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 26, line 30) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-11', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:07.027197 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:07.120372 [ 8430 ] {0e055039-d86f-4881-856f-52b92ea1aa84} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 27, line 31) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:07.131684 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:07.162936 [ 8442 ] {2a93d9de-282b-4b10-9d8e-6bc9d8a74a3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT ln(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 805, line 805) (in query: SELECT ln(NULL, NULL);) 2025.06.13 15:42:07.182465 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT ln(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:07.210761 [ 8431 ] {c314c70f-797e-4633-a0d1-e83a0db3accb} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1, line 1) (in query: SELECT BIT_AND();) 2025.06.13 15:42:07.216281 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:07.238202 [ 8430 ] {a5bee1e1-d55d-4f21-9f82-907427c67def} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 28, line 32) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-1111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:07.249373 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:07.340100 [ 8430 ] {c51cf290-f8cf-47c5-9eb7-ca7300b9e46c} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 29, line 33) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-11111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:07.345309 [ 8431 ] {0096f697-7862-4bf8-b704-d64a153e6daa} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 2, line 2) (in query: SELECT BIT_OR();) 2025.06.13 15:42:07.361532 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:07.361912 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:07.455508 [ 8442 ] {b6124a89-3c67-41e3-afd9-774827179456} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT log(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 807, line 807) (in query: SELECT log(NULL, NULL);) 2025.06.13 15:42:07.469429 [ 8431 ] {507a20a9-8f8a-45ff-a77e-125f4259bdc5} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 3, line 3) (in query: SELECT BIT_XOR();) 2025.06.13 15:42:07.476141 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT log(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:07.504195 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:07.560167 [ 8430 ] {71e50fe7-b7d3-44af-86be-641546de59cc} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 30, line 34) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:07.565844 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:07.626129 [ 8442 ] {780ade67-4412-4b42-b92a-1f8a118ffece} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 2, should be 1: In scope SELECT log10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 808, line 808) (in query: SELECT log10(NULL, NULL);) 2025.06.13 15:42:07.633947 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 2, should be 1: In scope SELECT log10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:07.679854 [ 8431 ] {80500fa4-af2c-4d39-b0a6-4f97f764b691} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 0, should be 1: In scope SELECT BLAKE3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 4, line 4) (in query: SELECT BLAKE3();) 2025.06.13 15:42:07.718331 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 0, should be 1: In scope SELECT BLAKE3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:07.740306 [ 8430 ] {9ec6cc97-6d7e-46e8-81cb-171f434cad83} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 31, line 35) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-1111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:07.760240 [ 18380 ] {01c76a69-a2c9-426e-ad08-110211ee9c9e} executeQuery: Code: 36. DB::Exception: Cannot rename column from nested struct to normal column and vice versa. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01213_alter_table_rename_nested.sql) (in query: /* ddl_entry=query-0000000005 */ ALTER TABLE test_dcr477mh.table_for_rename_nested (RENAME COLUMN n.renamed_x TO not_nested_x)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1704: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc1b1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:42:07.768186 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:07.798740 [ 8442 ] {e0b08835-4e9c-4eb7-a55c-aaac9e4e3983} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 2, should be 1: In scope SELECT log1p(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 809, line 809) (in query: SELECT log1p(NULL, NULL);) 2025.06.13 15:42:07.813271 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 2, should be 1: In scope SELECT log1p(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:07.824173 [ 18380 ] {01c76a69-a2c9-426e-ad08-110211ee9c9e} executeQuery: Code: 36. DB::Exception: Cannot rename column from nested struct to normal column and vice versa. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39046) (comment: 01213_alter_table_rename_nested.sql) (query 12, line 28) (in query: ALTER TABLE table_for_rename_nested RENAME COLUMN n.renamed_x TO not_nested_x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1704: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc1b1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:42:07.828224 [ 18380 ] {} TCPHandler: Code: 36. DB::Exception: Cannot rename column from nested struct to normal column and vice versa. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1704: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc1b1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:42:07.829369 [ 8431 ] {2feac92b-29f6-436e-a552-640219444806} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT CHARACTER_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 5, line 6) (in query: SELECT CHARACTER_LENGTH();) 2025.06.13 15:42:07.858349 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT CHARACTER_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:07.890025 [ 4098 ] {fa97ef3f-3e19-4830-b8ee-c397474ec958} executeQuery: Code: 53. DB::Exception: Type mismatch in IN or VALUES section. Expected: UInt8. Got: Tuple. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54944) (comment: 01421_assert_in_in.sql) (query 1, line 1) (in query: SELECT (1, 2) IN ((1, (2, 3)), (1 + 1, 1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, DB::Field::Types::Which&&) @ 0x000000002e2682cf 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:83: DB::Field DB::(anonymous namespace)::convertNumericType(DB::Field const&, DB::IDataType const&) @ 0x000000002e2596f6 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:223: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e254817 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d150b9c 10. ./build_docker/./src/Analyzer/SetUtils.cpp:133: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x000000002d14db41 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3511: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2fd24 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:07.895367 [ 4098 ] {} TCPHandler: Code: 53. DB::Exception: Type mismatch in IN or VALUES section. Expected: UInt8. Got: Tuple. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, DB::Field::Types::Which&&) @ 0x000000002e2682cf 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:83: DB::Field DB::(anonymous namespace)::convertNumericType(DB::Field const&, DB::IDataType const&) @ 0x000000002e2596f6 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:223: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e254817 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d150b9c 10. ./build_docker/./src/Analyzer/SetUtils.cpp:133: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x000000002d14db41 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3511: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2fd24 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:07.974427 [ 8430 ] {7f4944b2-68b5-4b13-877d-0f96a80042bb} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 32, line 36) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-11111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:07.982591 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.008259 [ 8442 ] {2abad6ba-2a71-48eb-ab44-ae968983e97b} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 2, should be 1: In scope SELECT log2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 810, line 810) (in query: SELECT log2(NULL, NULL);) 2025.06.13 15:42:08.015712 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 2, should be 1: In scope SELECT log2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:08.032645 [ 8431 ] {7e24e9de-a191-4f4c-b530-5ec8c2ef667c} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT CHAR_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 6, line 7) (in query: SELECT CHAR_LENGTH();) 2025.06.13 15:42:08.067593 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT CHAR_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:08.080836 [ 8430 ] {23500a65-2222-4152-a47f-c6db69462df6} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 33, line 37) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.097455 [ 8442 ] {da3890c0-79f4-4af2-a69c-57eabd202214} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 2, should be 1: In scope SELECT logTrace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 811, line 811) (in query: SELECT logTrace(NULL, NULL);) 2025.06.13 15:42:08.103276 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.112581 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 2, should be 1: In scope SELECT logTrace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:08.200915 [ 8430 ] {b5c78965-7dc3-48dd-a824-afa9d65fa480} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 34, line 38) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-1111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.205946 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.206014 [ 8431 ] {96ae2c1b-4507-4b72-95bf-f8e91c569d16} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 7, line 8) (in query: SELECT COVAR_POP();) 2025.06.13 15:42:08.222000 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:08.226528 [ 8442 ] {9ed727ae-3c97-4899-bad7-642c455081ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 812, line 812) (in query: SELECT lowCardinalityIndices(NULL, NULL);) 2025.06.13 15:42:08.238486 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:08.276922 [ 8430 ] {009b7325-5449-480f-adfc-a51c6fdf6d1b} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 35, line 39) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-11111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.282884 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.283175 [ 8431 ] {4dd7e01b-f449-4b6c-90e3-838b70e610a6} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 8, line 9) (in query: SELECT COVAR_SAMP();) 2025.06.13 15:42:08.291148 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:08.331908 [ 8442 ] {a33a9bee-cbed-4a8e-a5dd-4fad83d677c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 813, line 813) (in query: SELECT lowCardinalityKeys(NULL, NULL);) 2025.06.13 15:42:08.345766 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:08.372369 [ 8430 ] {3890ea3d-786d-45a4-a697-98c5f00edfe6} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 36, line 40) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.378510 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.406924 [ 8431 ] {984ac251-4acb-487b-b531-4465d84e4db2} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 0, should be 1: In scope SELECT CRC32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 9, line 10) (in query: SELECT CRC32();) 2025.06.13 15:42:08.432835 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 0, should be 1: In scope SELECT CRC32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:08.436812 [ 18380 ] {ba3a69f8-c0e7-4ceb-8f09-0a298594da9b} executeQuery: Code: 36. DB::Exception: Cannot rename column from one nested name to another. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01213_alter_table_rename_nested.sql) (in query: /* ddl_entry=query-0000000006 */ ALTER TABLE test_dcr477mh.table_for_rename_nested (RENAME COLUMN n.renamed_x TO q.renamed_x)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1694: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cb2de 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:42:08.482178 [ 8442 ] {8f1186f1-241d-43f7-aef3-30fa5548117c} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lower(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 814, line 814) (in query: SELECT lower(NULL, NULL);) 2025.06.13 15:42:08.491779 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lower(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:08.521132 [ 8430 ] {fcd1cffa-5531-4c8b-8e87-69a1ead55096} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 37, line 41) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.529422 [ 18380 ] {ba3a69f8-c0e7-4ceb-8f09-0a298594da9b} executeQuery: Code: 36. DB::Exception: Cannot rename column from one nested name to another. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39046) (comment: 01213_alter_table_rename_nested.sql) (query 13, line 30) (in query: ALTER TABLE table_for_rename_nested RENAME COLUMN n.renamed_x TO q.renamed_x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1694: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cb2de 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:42:08.541997 [ 18380 ] {} TCPHandler: Code: 36. DB::Exception: Cannot rename column from one nested name to another. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1694: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cb2de 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:42:08.542890 [ 8431 ] {dc98c086-b1ec-4485-a652-87a9ec5df066} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 0, should be 1: In scope SELECT CRC32IEEE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 10, line 11) (in query: SELECT CRC32IEEE();) 2025.06.13 15:42:08.546864 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.559861 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 0, should be 1: In scope SELECT CRC32IEEE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:08.620440 [ 8442 ] {bbcbf3ea-3152-47c3-939d-aace9d35bfc4} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 2, should be 1: In scope SELECT lowerUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 815, line 815) (in query: SELECT lowerUTF8(NULL, NULL);) 2025.06.13 15:42:08.642286 [ 8431 ] {5b230b58-dce8-459d-922a-e631d57ff411} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 0, should be 1: In scope SELECT CRC64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 11, line 12) (in query: SELECT CRC64();) 2025.06.13 15:42:08.644954 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 2, should be 1: In scope SELECT lowerUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:08.676536 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 0, should be 1: In scope SELECT CRC64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:08.698813 [ 8430 ] {c1b2c962-aa81-4484-b2bc-39acd7f026b2} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 38, line 42) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.712763 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.830410 [ 8430 ] {907ec21c-17e0-4bb8-81d6-e68004f6a9fd} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 39, line 43) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.845477 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.923715 [ 8430 ] {a7d05945-6571-4236-8125-db4140cbe7d3} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 40, line 44) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:08.945679 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:09.054660 [ 8431 ] {4c3b90e1-8121-41a5-9af6-43865019d1a6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT DATE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 13, line 14) (in query: SELECT DATE();) 2025.06.13 15:42:09.062869 [ 8430 ] {3a32d533-d03a-4a1e-aaac-5c0b7b598566} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 41, line 45) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:09.075902 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT DATE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:09.089408 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:09.104754 [ 18380 ] {ea6af3d7-21a5-48b1-a289-7df6dbea518e} executeQuery: Code: 36. DB::Exception: Cannot rename column from nested struct to normal column and vice versa. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01213_alter_table_rename_nested.sql) (in query: /* ddl_entry=query-0000000007 */ ALTER TABLE test_dcr477mh.table_for_rename_nested (RENAME COLUMN value1 TO q.renamed_x)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1704: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc1b1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:42:09.259147 [ 18380 ] {ea6af3d7-21a5-48b1-a289-7df6dbea518e} executeQuery: Code: 36. DB::Exception: Cannot rename column from nested struct to normal column and vice versa. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39046) (comment: 01213_alter_table_rename_nested.sql) (query 14, line 32) (in query: ALTER TABLE table_for_rename_nested RENAME COLUMN value1 TO q.renamed_x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1704: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc1b1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:42:09.264317 [ 18380 ] {} TCPHandler: Code: 36. DB::Exception: Cannot rename column from nested struct to normal column and vice versa. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1704: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc1b1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:42:09.272172 [ 8431 ] {fd6318ef-d743-4957-8d38-993e5006ee0b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 14, line 15) (in query: SELECT DATE_DIFF();) 2025.06.13 15:42:09.278563 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:09.279085 [ 8430 ] {295fa4ad-04be-41dc-946f-67b087c8e562} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 42, line 46) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:09.291322 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:09.447092 [ 8431 ] {eb22fdd0-b61c-40ee-9367-0d6fae6c21fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT DATE_FORMAT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 15, line 16) (in query: SELECT DATE_FORMAT();) 2025.06.13 15:42:09.447927 [ 8430 ] {9f69f8c0-f6a6-4e71-913c-588cd7c2b3c9} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 43, line 47) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:09.455069 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-1111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-1111111111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:09.455422 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT DATE_FORMAT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:09.545239 [ 8430 ] {b254ae35-ace9-4935-8c85-7ca28359dd95} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 44, line 48) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:09.556271 [ 8431 ] {9cf1d9e6-d26f-415d-8d91-225943e1eed0} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 0, should be 2 or 3: In scope SELECT DATE_TRUNC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 16, line 17) (in query: SELECT DATE_TRUNC();) 2025.06.13 15:42:09.572181 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-11111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-11111111111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:09.587245 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 0, should be 2 or 3: In scope SELECT DATE_TRUNC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:09.707840 [ 8430 ] {1fa78fe7-11a7-4890-b22a-da1dcaeebfb7} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111111111', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 45, line 49) (in query: SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111111111', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:09.713297 [ 8431 ] {6d454067-3684-4800-a6ef-e5ce4b5b6f03} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT DAY(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 17, line 18) (in query: SELECT DAY();) 2025.06.13 15:42:09.732764 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.-111111111111111111111' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.-111111111111111111111', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:09.744163 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT DAY(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:09.811385 [ 18380 ] {c4f0797d-c271-4bb6-9fa9-93e275c1cf47} executeQuery: Code: 48. DB::Exception: Cannot rename whole Nested struct. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01213_alter_table_rename_nested.sql) (in query: /* ddl_entry=query-0000000008 */ ALTER TABLE test_dcr477mh.table_for_rename_nested (RENAME COLUMN n TO renamed_n)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1659: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cae3d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:42:09.828135 [ 8431 ] {e8fceb88-c4ab-4a36-9f26-f5115957520a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT DAYOFMONTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 18, line 19) (in query: SELECT DAYOFMONTH();) 2025.06.13 15:42:09.838716 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT DAYOFMONTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:09.850690 [ 8430 ] {216142fc-ffe6-460d-97e2-2c7d4252fab2} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+1' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+1', 0). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 46, line 51) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+1', 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:09.854393 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+1' as DateTime64(0): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+1', 0). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:09.885079 [ 18380 ] {c4f0797d-c271-4bb6-9fa9-93e275c1cf47} executeQuery: Code: 48. DB::Exception: Cannot rename whole Nested struct. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39046) (comment: 01213_alter_table_rename_nested.sql) (query 15, line 34) (in query: -- Currently not implemented ALTER TABLE table_for_rename_nested RENAME COLUMN n TO renamed_n;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1659: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cae3d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:42:09.890958 [ 18380 ] {} TCPHandler: Code: 48. DB::Exception: Cannot rename whole Nested struct. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/AlterCommands.cpp:1659: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cae3d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:42:09.943128 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:09.952267 [ 8431 ] {8fb45565-b87f-4c8c-8eac-8b6953a5dc68} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT DAYOFWEEK(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 19, line 20) (in query: SELECT DAYOFWEEK();) 2025.06.13 15:42:09.968976 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT DAYOFWEEK(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:10.094847 [ 8431 ] {ffc4a56e-9a78-49f6-ad4d-35e3fcba5974} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT DAYOFYEAR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 20, line 21) (in query: SELECT DAYOFYEAR();) 2025.06.13 15:42:10.102857 [ 8430 ] {4d00d41b-32e6-4f8b-a10f-2a659dcc7929} executeQuery: Code: 69. DB::Exception: Scale 10 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.++11', 10). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 47, line 52) (in query: SELECT toDateTime64('2011-11-11 11:11:11.++11', 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:10.111967 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT DAYOFYEAR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:10.114168 [ 8430 ] {} TCPHandler: Code: 69. DB::Exception: Scale 10 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.++11', 10). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:10.206082 [ 8431 ] {185a5229-6a6c-4249-a7cb-9823d4871aa4} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 0, should be 1: In scope SELECT FORMAT_BYTES(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 21, line 22) (in query: SELECT FORMAT_BYTES();) 2025.06.13 15:42:10.214571 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 0, should be 1: In scope SELECT FORMAT_BYTES(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:10.228498 [ 8430 ] {394ec84e-2e08-4e26-92a8-07a9452bf526} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+111' as DateTime64(3): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+111', 3). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 48, line 53) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+111', 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:10.241237 [ 8442 ] {81390a63-8e02-4085-b4e1-f529909c4d6b} executeQuery: Code: 36. DB::Exception: Map cannot have a key of type Nullable(Nothing): In scope SELECT map(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 823, line 824) (in query: SELECT map(NULL, NULL);) 2025.06.13 15:42:10.247072 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+111' as DateTime64(3): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+111', 3). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:10.253062 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Map cannot have a key of type Nullable(Nothing): In scope SELECT map(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:42:10.337127 [ 8430 ] {b14f2584-acd4-4239-91e5-f31b7e7eb843} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+++1111' as DateTime64(5): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+++1111', 5). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 49, line 54) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+++1111', 5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:10.362498 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+++1111' as DateTime64(5): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+++1111', 5). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:10.370809 [ 7279 ] {cc5f49c5-d9e3-46ae-8142-f69ac681f1f7} executeQuery: Code: 36. DB::Exception: Cannot alter settings, because table engine doesn't support settings changes. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55004) (comment: 01089_alter_settings_old_format.sql) (query 4, line 12) (in query: ALTER TABLE old_format_mt MODIFY SETTING enable_mixed_granularity_parts = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3648: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cca83d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:42:10.381063 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:10.385395 [ 7279 ] {} TCPHandler: Code: 36. DB::Exception: Cannot alter settings, because table engine doesn't support settings changes. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3648: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cca83d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:42:10.437814 [ 8430 ] {f0d5bea7-ec7f-4135-b8eb-503389704470} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+11111' as DateTime64(7): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+11111', 7). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 50, line 55) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+11111', 7);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:10.445899 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+11111' as DateTime64(7): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+11111', 7). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:10.500086 [ 8431 ] {59ef8d6f-1517-4d8c-8f4a-e18cea05a218} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 0, should be 1: In scope SELECT FROM_BASE64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 23, line 24) (in query: SELECT FROM_BASE64();) 2025.06.13 15:42:10.514740 [ 8430 ] {06f99686-4d99-4dc2-a668-cecf9ccbfd24} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+++++111111' as DateTime64(2): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++111111', 2). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 51, line 56) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+++++111111', 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:10.524206 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 0, should be 1: In scope SELECT FROM_BASE64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:10.559406 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+++++111111' as DateTime64(2): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++111111', 2). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:10.688714 [ 8431 ] {d1117236-cae3-4606-a772-dadc3f4187d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 0, should be 1: In scope SELECT FROM_DAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 24, line 25) (in query: SELECT FROM_DAYS();) 2025.06.13 15:42:10.693563 [ 8430 ] {cbef60d0-73f8-4cc7-b84a-8fbcf2523f9f} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+1111111' as DateTime64(1): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+1111111', 1). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 52, line 57) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+1111111', 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:10.696268 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 0, should be 1: In scope SELECT FROM_DAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:10.703676 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+1111111' as DateTime64(1): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+1111111', 1). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:10.830904 [ 3894 ] {e8f96a2e-0558-4b40-bcf7-e43f9dac3276} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42954) (comment: 01201_drop_column_compact_part_replicated_zookeeper_long.sql) (query 13, line 28) (in query: select * from mt_compact where a > 1 order by a, s limit 10;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:42:10.849984 [ 3894 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:42:10.865500 [ 8431 ] {cd63f01e-c6e1-4041-b05d-c780ee3c8e7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestamp doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT FROM_UNIXTIME(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 25, line 26) (in query: SELECT FROM_UNIXTIME();) 2025.06.13 15:42:10.871511 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestamp doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT FROM_UNIXTIME(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:10.898382 [ 8430 ] {dae8afa8-53cd-4f5a-9464-b7f839ee00de} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.++++++11111111' as DateTime64(8): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++11111111', 8). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 53, line 58) (in query: SELECT toDateTime64('2011-11-11 11:11:11.++++++11111111', 8);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:10.908860 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.++++++11111111' as DateTime64(8): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++11111111', 8). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:10.980095 [ 8431 ] {a05770c9-049c-4a51-a07a-dd80410edddf} executeQuery: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 0, should be 1 or 2: In scope SELECT HOUR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 26, line 27) (in query: SELECT HOUR();) 2025.06.13 15:42:11.006139 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 0, should be 1 or 2: In scope SELECT HOUR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:11.008902 [ 8430 ] {5fba6884-fca5-4b08-bc92-9a5e5bdec731} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+111111111' as DateTime64(9): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+111111111', 9). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 54, line 59) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+111111111', 9);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:11.023005 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+111111111' as DateTime64(9): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+111111111', 9). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:11.083933 [ 8431 ] {65061d68-6d34-4e5a-b2f1-59497923adc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 0, should be 1: In scope SELECT INET6_ATON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 27, line 28) (in query: SELECT INET6_ATON();) 2025.06.13 15:42:11.094785 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 0, should be 1: In scope SELECT INET6_ATON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:11.117929 [ 8442 ] {9c0549f7-a41e-4f0b-a004-0b072cd9a2ea} executeQuery: Code: 43. DB::Exception: Function mapContains requires at least one argument of type Map: In scope SELECT mapContains(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 828, line 829) (in query: SELECT mapContains(NULL, NULL);) 2025.06.13 15:42:11.122478 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Function mapContains requires at least one argument of type Map: In scope SELECT mapContains(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:11.125715 [ 8430 ] {07d71ee6-dabe-48cd-8572-322f698dce94} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+++++++1111111111' as DateTime64(6): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++++1111111111', 6). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 55, line 60) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+++++++1111111111', 6);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:11.142217 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+++++++1111111111' as DateTime64(6): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++++1111111111', 6). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:11.154832 [ 8431 ] {86483e28-7347-45d2-a333-4aa7e49f6319} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 0, should be 1: In scope SELECT INET6_NTOA(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 28, line 29) (in query: SELECT INET6_NTOA();) 2025.06.13 15:42:11.176182 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 0, should be 1: In scope SELECT INET6_NTOA(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:11.320956 [ 8431 ] {d9a243ac-3994-4e1e-a3bc-066f8a5d9d33} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 0, should be 1: In scope SELECT INET_ATON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 29, line 30) (in query: SELECT INET_ATON();) 2025.06.13 15:42:11.329885 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 0, should be 1: In scope SELECT INET_ATON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:11.334963 [ 8430 ] {0e365d82-bbb0-4da4-b859-848465ac0aa1} executeQuery: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+11111111111' as DateTime64(4): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+11111111111', 4). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 56, line 61) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+11111111111', 4);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:11.345273 [ 8430 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2011-11-11 11:11:11.+11111111111' as DateTime64(4): syntax error at position 20 (parsed just '2011-11-11 11:11:11.'): In scope SELECT toDateTime64('2011-11-11 11:11:11.+11111111111', 4). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b1d9a21 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1caabf 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02db8e 8. ./src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05c5ac 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05b4a3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:11.442279 [ 8431 ] {3402bd77-38a1-4cf8-a411-c37aa99dea9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 0, should be 1: In scope SELECT INET_NTOA(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 30, line 31) (in query: SELECT INET_NTOA();) 2025.06.13 15:42:11.484042 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 0, should be 1: In scope SELECT INET_NTOA(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:11.491644 [ 8430 ] {879debeb-3925-45d0-9504-0e7fc7207d83} executeQuery: Code: 69. DB::Exception: Scale 11 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++++111111111111', 11). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 57, line 62) (in query: SELECT toDateTime64('2011-11-11 11:11:11.++++++++111111111111', 11);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:11.501251 [ 8430 ] {} TCPHandler: Code: 69. DB::Exception: Scale 11 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++++111111111111', 11). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:11.620708 [ 8431 ] {a74be2f2-b72e-44f4-9e8b-c44fbf9dcecf} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 0, should be 2: In scope SELECT IPv4CIDRToRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 31, line 32) (in query: SELECT IPv4CIDRToRange();) 2025.06.13 15:42:11.640429 [ 8430 ] {a8946d7c-39a9-49d8-887b-400eb1df53cd} executeQuery: Code: 69. DB::Exception: Scale 15 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+1111111111111', 15). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 58, line 63) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+1111111111111', 15);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:11.650310 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 0, should be 2: In scope SELECT IPv4CIDRToRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:11.738904 [ 8430 ] {} TCPHandler: Code: 69. DB::Exception: Scale 15 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+1111111111111', 15). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:11.848970 [ 8431 ] {7ae06f57-4a72-45e5-a06d-cd0b24e03f6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 0, should be 1: In scope SELECT IPv4NumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 32, line 33) (in query: SELECT IPv4NumToString();) 2025.06.13 15:42:11.856862 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 0, should be 1: In scope SELECT IPv4NumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:11.864462 [ 8430 ] {97cd1ec9-5075-4f87-8fa0-5d74906b0e75} executeQuery: Code: 69. DB::Exception: Scale 13 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++++++11111111111111', 13). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 59, line 64) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+++++++++11111111111111', 13);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:11.888016 [ 8430 ] {} TCPHandler: Code: 69. DB::Exception: Scale 13 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++++++11111111111111', 13). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:12.080016 [ 8431 ] {d1895d31-d518-4008-9058-9299df34b6d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 0, should be 1: In scope SELECT IPv4NumToStringClassC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 33, line 34) (in query: SELECT IPv4NumToStringClassC();) 2025.06.13 15:42:12.083712 [ 8430 ] {ebda0a58-0f0d-4bda-9871-5d0322bc45f3} executeQuery: Code: 69. DB::Exception: Scale 12 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+111111111111111', 12). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 60, line 65) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+111111111111111', 12);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:12.091279 [ 8430 ] {} TCPHandler: Code: 69. DB::Exception: Scale 12 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+111111111111111', 12). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:12.101872 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 0, should be 1: In scope SELECT IPv4NumToStringClassC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:12.254995 [ 8431 ] {6f3b8bb3-83ee-4ffc-84d9-c326d7aeaa02} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 34, line 35) (in query: SELECT IPv4StringToNum();) 2025.06.13 15:42:12.286997 [ 8430 ] {06e45f0e-f7b8-4cff-a5cc-a1684441a75e} executeQuery: Code: 69. DB::Exception: Scale 16 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++++++1111111111111111', 16). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 61, line 66) (in query: SELECT toDateTime64('2011-11-11 11:11:11.++++++++++1111111111111111', 16);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:12.287703 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:12.307867 [ 8430 ] {} TCPHandler: Code: 69. DB::Exception: Scale 16 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++++++1111111111111111', 16). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:12.371645 [ 8431 ] {abffcf3b-b07a-4390-8e74-fc2589cb8f5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNumOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 35, line 36) (in query: SELECT IPv4StringToNumOrDefault();) 2025.06.13 15:42:12.410531 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNumOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:12.416927 [ 8430 ] {c51f3a7a-e1d1-44cd-aae1-4713170b34a8} executeQuery: Code: 69. DB::Exception: Scale 14 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+11111111111111111', 14). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 62, line 67) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+11111111111111111', 14);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:12.417893 [ 8442 ] {eec7f7b5-8d46-4f1b-918f-41b8e46cd3b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 2, should be 1: In scope SELECT mapKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 835, line 836) (in query: SELECT mapKeys(NULL, NULL);) 2025.06.13 15:42:12.515970 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 2, should be 1: In scope SELECT mapKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:12.516091 [ 8430 ] {} TCPHandler: Code: 69. DB::Exception: Scale 14 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+11111111111111111', 14). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:12.612382 [ 8431 ] {21c60424-4ea3-498f-ab7e-3e9839e914a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNumOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 36, line 37) (in query: SELECT IPv4StringToNumOrNull();) 2025.06.13 15:42:12.635659 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNumOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:12.657457 [ 8430 ] {a22958b3-f65e-4b1f-9aa5-277339d7c535} executeQuery: Code: 69. DB::Exception: Scale 15 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++++++++111111111111111111', 15). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 63, line 68) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+++++++++++111111111111111111', 15);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:12.669443 [ 8430 ] {} TCPHandler: Code: 69. DB::Exception: Scale 15 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+++++++++++111111111111111111', 15). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:12.762446 [ 8431 ] {bda7ea44-7210-46a6-8c61-34b021741718} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 0, should be 1: In scope SELECT IPv4ToIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 37, line 38) (in query: SELECT IPv4ToIPv6();) 2025.06.13 15:42:12.763092 [ 8430 ] {2af8f0b0-08f3-422d-84a4-131e28c0f58c} executeQuery: Code: 69. DB::Exception: Scale 17 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+1111111111111111111', 17). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 64, line 69) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+1111111111111111111', 17);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:12.770907 [ 8430 ] {} TCPHandler: Code: 69. DB::Exception: Scale 17 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+1111111111111111111', 17). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:12.772591 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 0, should be 1: In scope SELECT IPv4ToIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:12.844523 [ 8431 ] {3ae3760f-d4be-4e33-be00-eadff3d7bc19} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 0, should be 2: In scope SELECT IPv6CIDRToRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 38, line 39) (in query: SELECT IPv6CIDRToRange();) 2025.06.13 15:42:12.864215 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 0, should be 2: In scope SELECT IPv6CIDRToRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:12.896971 [ 8430 ] {20156efb-0286-41af-b175-9c5e5bd7eb2d} executeQuery: Code: 69. DB::Exception: Scale 19 is out of bounds (max scale: 18): In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++++++++11111111111111111111', 19). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 65, line 70) (in query: SELECT toDateTime64('2011-11-11 11:11:11.++++++++++++11111111111111111111', 19);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccaf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c406056 6. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:21: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c40212b 7. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 8. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 10. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:42:12.914547 [ 8430 ] {} TCPHandler: Code: 69. DB::Exception: Scale 19 is out of bounds (max scale: 18): In scope SELECT toDateTime64('2011-11-11 11:11:11.++++++++++++11111111111111111111', 19). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccaf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c406056 6. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:21: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c40212b 7. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 8. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 10. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:42:12.990629 [ 8431 ] {c00118e0-c600-4a9a-b0df-a3c9edc4ec03} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 0, should be 1: In scope SELECT IPv6NumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 39, line 40) (in query: SELECT IPv6NumToString();) 2025.06.13 15:42:13.032166 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 0, should be 1: In scope SELECT IPv6NumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:13.089534 [ 4171 ] {ff780a4f-6c50-48d7-9537-56706e201bde} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46380) (comment: 02021_create_database_with_comment.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_7;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:42:13.111563 [ 8430 ] {b2bb0341-ca87-47c9-a7f3-9f34362d41f5} executeQuery: Code: 69. DB::Exception: Scale 18 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+111111111111111111111', 18). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39024) (comment: 01340_datetime64_fpe.sql) (query 66, line 71) (in query: SELECT toDateTime64('2011-11-11 11:11:11.+111111111111111111111', 18);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:13.114316 [ 4171 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:42:13.123667 [ 8430 ] {} TCPHandler: Code: 69. DB::Exception: Scale 18 is too large for DateTime64. Maximum is up to nanoseconds (9).: In scope SELECT toDateTime64('2011-11-11 11:11:11.+111111111111111111111', 18). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:25: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000002c402230 6. std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, unsigned int&, String&&) @ 0x0000000020bce3fb 7. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x0000000020bce206 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002b05b0da 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x000000002b05ac67 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:42:13.199420 [ 8431 ] {a60e6225-d87b-495b-92f0-19bd81701fa5} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 40, line 41) (in query: SELECT IPv6StringToNum();) 2025.06.13 15:42:13.217003 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:13.315760 [ 8431 ] {98162919-0dee-4f9e-99cd-add353c01b29} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNumOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 41, line 42) (in query: SELECT IPv6StringToNumOrDefault();) 2025.06.13 15:42:13.333153 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNumOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:13.456771 [ 8431 ] {fa4c8261-cb20-4d82-b402-40b5cace4d45} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNumOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 42, line 43) (in query: SELECT IPv6StringToNumOrNull();) 2025.06.13 15:42:13.497798 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNumOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:13.589562 [ 8431 ] {49e3d54e-92ab-4404-92ad-61a42f80aab8} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 0, should be 1: In scope SELECT JSONAllPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 43, line 44) (in query: SELECT JSONAllPaths();) 2025.06.13 15:42:13.618755 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 0, should be 1: In scope SELECT JSONAllPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:13.786898 [ 8431 ] {cae8d30d-5206-4695-956e-b93bb045c8f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONAllPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 44, line 45) (in query: SELECT JSONAllPathsWithTypes();) 2025.06.13 15:42:13.792284 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONAllPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:13.816225 [ 3931 ] {7ce61a40-3f9d-4284-99f5-075f3524d455} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38990) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:42:13.842158 [ 3931 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:42:13.880454 [ 8431 ] {29c1b810-5820-4ead-be92-bc375f327e6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 0, should be 1: In scope SELECT JSONArrayLength(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 45, line 46) (in query: SELECT JSONArrayLength();) 2025.06.13 15:42:13.885629 [ 8442 ] {9aec528c-89a4-4722-a540-e2f6a9969e39} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 2, should be 1: In scope SELECT mapValues(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 843, line 844) (in query: SELECT mapValues(NULL, NULL);) 2025.06.13 15:42:13.896712 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 2, should be 1: In scope SELECT mapValues(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:13.898906 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 0, should be 1: In scope SELECT JSONArrayLength(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:13.996344 [ 8431 ] {36032710-00de-4c3c-b9bb-9d69696a6523} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 0, should be 1: In scope SELECT JSONDynamicPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 46, line 47) (in query: SELECT JSONDynamicPaths();) 2025.06.13 15:42:14.033520 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 0, should be 1: In scope SELECT JSONDynamicPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:14.217120 [ 8431 ] {c4235782-27f9-4be6-95b1-5095dc6e56c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONDynamicPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 47, line 48) (in query: SELECT JSONDynamicPathsWithTypes();) 2025.06.13 15:42:14.223982 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONDynamicPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:14.291515 [ 8442 ] {18fe826d-7351-4a14-a352-93fd5b3adefe} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 2, should be 1: In scope SELECT materialize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 845, line 846) (in query: SELECT materialize(NULL, NULL);) 2025.06.13 15:42:14.319985 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 2, should be 1: In scope SELECT materialize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:14.380134 [ 8431 ] {2282535a-3657-4cdb-b85e-cfb64691a4a7} executeQuery: Code: 42. DB::Exception: Function JSONExtract requires at least two arguments: In scope SELECT JSONExtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 48, line 49) (in query: SELECT JSONExtract();) 2025.06.13 15:42:14.389505 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtract requires at least two arguments: In scope SELECT JSONExtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:14.530660 [ 8431 ] {4283e4e5-784d-4056-b859-537b99886a36} executeQuery: Code: 42. DB::Exception: Function JSONExtractArrayRaw requires at least one argument: In scope SELECT JSONExtractArrayRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 49, line 50) (in query: SELECT JSONExtractArrayRaw();) 2025.06.13 15:42:14.543981 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtractArrayRaw requires at least one argument: In scope SELECT JSONExtractArrayRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:14.617214 [ 8431 ] {ed95e616-3b36-488e-8b2d-b90f1e00be49} executeQuery: Code: 42. DB::Exception: Function JSONExtractBool requires at least one argument: In scope SELECT JSONExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 50, line 51) (in query: SELECT JSONExtractBool();) 2025.06.13 15:42:14.629846 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtractBool requires at least one argument: In scope SELECT JSONExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:14.767751 [ 8431 ] {0780b510-dc4b-4fee-b191-fe6d9dd3dc28} executeQuery: Code: 42. DB::Exception: Function JSONExtractFloat requires at least one argument: In scope SELECT JSONExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 51, line 52) (in query: SELECT JSONExtractFloat();) 2025.06.13 15:42:14.779574 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtractFloat requires at least one argument: In scope SELECT JSONExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:14.873745 [ 8431 ] {7c743237-e890-4ec8-9ec2-af3722efdafc} executeQuery: Code: 42. DB::Exception: Function JSONExtractInt requires at least one argument: In scope SELECT JSONExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 52, line 53) (in query: SELECT JSONExtractInt();) 2025.06.13 15:42:14.893872 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtractInt requires at least one argument: In scope SELECT JSONExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:14.990520 [ 8431 ] {221ae0e2-a805-4cc2-a122-4cf8adc478be} executeQuery: Code: 42. DB::Exception: Function JSONExtractKeys requires at least one argument: In scope SELECT JSONExtractKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 53, line 54) (in query: SELECT JSONExtractKeys();) 2025.06.13 15:42:15.003557 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtractKeys requires at least one argument: In scope SELECT JSONExtractKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:15.010780 [ 8432 ] {b897877c-9801-4a2c-89b1-4ad092c5ace0} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `value_` in scope SELECT value_ FROM test_table SETTINGS enable_analyzer = 1. Maybe you meant: ['value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39098) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT value_ FROM test_table SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:15.030075 [ 8432 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `value_` in scope SELECT value_ FROM test_table SETTINGS enable_analyzer = 1. Maybe you meant: ['value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:15.269495 [ 8431 ] {25f4dc90-5b4e-4472-9a44-f89b0f9eabff} executeQuery: Code: 42. DB::Exception: Function JSONExtractKeysAndValues requires at least two arguments: In scope SELECT JSONExtractKeysAndValues(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 54, line 55) (in query: SELECT JSONExtractKeysAndValues();) 2025.06.13 15:42:15.282355 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtractKeysAndValues requires at least two arguments: In scope SELECT JSONExtractKeysAndValues(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:15.432777 [ 8431 ] {fdaaa8e7-aa1b-46bf-a781-65b0c6916102} executeQuery: Code: 42. DB::Exception: Function JSONExtractKeysAndValuesRaw requires at least one argument: In scope SELECT JSONExtractKeysAndValuesRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 55, line 56) (in query: SELECT JSONExtractKeysAndValuesRaw();) 2025.06.13 15:42:15.450636 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtractKeysAndValuesRaw requires at least one argument: In scope SELECT JSONExtractKeysAndValuesRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:15.559032 [ 8431 ] {0309a977-2af6-441a-9dfb-7e2b9a0dfec7} executeQuery: Code: 42. DB::Exception: Function JSONExtractRaw requires at least one argument: In scope SELECT JSONExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 56, line 57) (in query: SELECT JSONExtractRaw();) 2025.06.13 15:42:15.566182 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtractRaw requires at least one argument: In scope SELECT JSONExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:15.656518 [ 8431 ] {7d59b69a-5025-4f17-859b-599d512da6d5} executeQuery: Code: 42. DB::Exception: Function JSONExtractString requires at least one argument: In scope SELECT JSONExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 57, line 58) (in query: SELECT JSONExtractString();) 2025.06.13 15:42:15.686889 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtractString requires at least one argument: In scope SELECT JSONExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:15.718733 [ 7279 ] {c19cecfc-28b6-459b-9873-f419c05a14cc} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randChiSquared should be greater than zero: In scope SELECT randChiSquared(-1e-7). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39102) (comment: 03213_rand_dos.sql) (query 1, line 1) (in query: SELECT randChiSquared(-0.0000001);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206065d4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:15.740365 [ 7279 ] {} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randChiSquared should be greater than zero: In scope SELECT randChiSquared(-1e-7). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206065d4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:15.766247 [ 8432 ] {cd3d40e7-b9ea-4eae-99e6-8c7f4ca273bd} executeQuery: Code: 47. DB::Exception: Identifier 'test_table.value_' cannot be resolved from table with name test_13.test_table. In scope SELECT test_table.value_ FROM test_table SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39108) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT test_table.value_ FROM test_table SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:42:15.790261 [ 8432 ] {} TCPHandler: Code: 47. DB::Exception: Identifier 'test_table.value_' cannot be resolved from table with name test_13.test_table. In scope SELECT test_table.value_ FROM test_table SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:42:15.851303 [ 8431 ] {9a87f8cd-655b-47c8-9f20-64438f2a9173} executeQuery: Code: 42. DB::Exception: Function JSONExtractUInt requires at least one argument: In scope SELECT JSONExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 58, line 59) (in query: SELECT JSONExtractUInt();) 2025.06.13 15:42:15.888156 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtractUInt requires at least one argument: In scope SELECT JSONExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:15.917749 [ 7279 ] {e15148e9-f18b-46bc-b38c-4235d1b50b4f} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randChiSquared should be greater than zero: In scope SELECT randChiSquared(-0.). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39102) (comment: 03213_rand_dos.sql) (query 2, line 2) (in query: SELECT randChiSquared(-0.0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206065d4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:15.921990 [ 7279 ] {} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randChiSquared should be greater than zero: In scope SELECT randChiSquared(-0.). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000206065d4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:15.952721 [ 8431 ] {4e23636b-1c7b-4512-ba79-e598797ebc2d} executeQuery: Code: 42. DB::Exception: Function JSONHas requires at least one argument: In scope SELECT JSONHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 59, line 60) (in query: SELECT JSONHas();) 2025.06.13 15:42:15.958131 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONHas requires at least one argument: In scope SELECT JSONHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:15.971376 [ 7012 ] {f9b6668d-6260-44cc-964c-b76578c7014f} InterpreterCheckQuery: Check query for table test_liccri1v.tp_1 (5ddf2711-444f-4e82-9f1e-fb4841f4cd2f) 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.20286.altinityantalya (altinity build)) 2025.06.13 15:42:16.043948 [ 8431 ] {2549429c-0d3c-4e8d-b277-cb979e55acfe} executeQuery: Code: 42. DB::Exception: Function JSONKey requires at least one argument: In scope SELECT JSONKey(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 60, line 61) (in query: SELECT JSONKey();) 2025.06.13 15:42:16.055744 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONKey requires at least one argument: In scope SELECT JSONKey(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:16.152453 [ 7279 ] {2a3b7261-49bf-4485-937e-d140f3d6abc7} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randStudentT should be greater than zero: In scope SELECT randStudentT(-0.). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39102) (comment: 03213_rand_dos.sql) (query 3, line 3) (in query: SELECT randStudentT(-0.);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020607c2d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:16.164510 [ 8431 ] {1e9d25e3-02a3-4e00-8290-29f70ea8bb56} executeQuery: Code: 42. DB::Exception: Function JSONLength requires at least one argument: In scope SELECT JSONLength(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 61, line 62) (in query: SELECT JSONLength();) 2025.06.13 15:42:16.169681 [ 7279 ] {} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randStudentT should be greater than zero: In scope SELECT randStudentT(-0.). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020607c2d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:16.192461 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONLength requires at least one argument: In scope SELECT JSONLength(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:16.251164 [ 8101 ] {75a37e4c-3b06-4ab2-93bd-16a16ff2c24c} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_tabl.value_` in scope SELECT test_tabl.value_ FROM test_table SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39124) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT test_tabl.value_ FROM test_table SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:16.264075 [ 8101 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `test_tabl.value_` in scope SELECT test_tabl.value_ FROM test_table SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:16.312656 [ 7755 ] {d1effa74-fe3a-446c-a30e-71d63453552b} executeQuery: Code: 47. DB::Exception: JOIN ALL RIGHT JOIN ... USING (s) using identifier 's' cannot be resolved from left table expression. In scope SELECT count() FROM (SELECT [1], count(1)) AS t1 ALL RIGHT JOIN (SELECT number AS s FROM numbers(2)) AS t2 USING (s). (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39056) (comment: 01010_pm_join_all_join_bug.sql) (query 9, line 13) (in query: SELECT count() FROM ( SELECT [1], count(1) ) AS t1 ALL RIGHT JOIN ( SELECT number AS s FROM numbers(2) ) AS t2 USING (s);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000002cc5bacf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc56579 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:42:16.331405 [ 7755 ] {} TCPHandler: Code: 47. DB::Exception: JOIN ALL RIGHT JOIN ... USING (s) using identifier 's' cannot be resolved from left table expression. In scope SELECT count() FROM (SELECT [1], count(1)) AS t1 ALL RIGHT JOIN (SELECT number AS s FROM numbers(2)) AS t2 USING (s). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x000000002cc5bacf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5255: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc56579 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:42:16.332963 [ 8431 ] {6a4d753f-c5ca-4de0-a1de-b14847519ffd} executeQuery: Code: 35. DB::Exception: Function JSONMergePatch requires at least one argument.: In scope SELECT JSONMergePatch(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 62, line 63) (in query: SELECT JSONMergePatch();) 2025.06.13 15:42:16.352436 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function JSONMergePatch requires at least one argument.: In scope SELECT JSONMergePatch(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:16.528335 [ 7279 ] {b632e51a-22dc-4f93-b673-7fd1f87fe055} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randFisherF should be greater than zero: In scope SELECT randFisherF(-0., 1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39102) (comment: 03213_rand_dos.sql) (query 4, line 4) (in query: SELECT randFisherF(-0., 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020608e09 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:16.534266 [ 7279 ] {} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randFisherF should be greater than zero: In scope SELECT randFisherF(-0., 1). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020608e09 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:16.551339 [ 8431 ] {5f254499-af6c-412d-a2d0-63b9eaaa80cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 0, should be 1: In scope SELECT JSONSharedDataPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 63, line 64) (in query: SELECT JSONSharedDataPaths();) 2025.06.13 15:42:16.567108 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 0, should be 1: In scope SELECT JSONSharedDataPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:16.628414 [ 7279 ] {ca2ffd24-94fd-4b13-ad60-721ccd6aae78} executeQuery: Code: 36. DB::Exception: Argument (degrees of freedom) of function randFisherF should be greater than zero: In scope SELECT randFisherF(1, -0.). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39102) (comment: 03213_rand_dos.sql) (query 5, line 5) (in query: SELECT randFisherF(1, -0.);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020608e09 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:16.635184 [ 7279 ] {} TCPHandler: Code: 36. DB::Exception: Argument (degrees of freedom) of function randFisherF should be greater than zero: In scope SELECT randFisherF(1, -0.). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::FunctionRandomDistribution::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020608e09 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:16.692340 [ 8431 ] {352719d5-0262-4962-9b1e-704364fe0abe} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 64, line 65) (in query: SELECT JSONSharedDataPathsWithTypes();) 2025.06.13 15:42:16.693798 [ 8432 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:16.714754 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:16.794862 [ 8101 ] {3532ff00-3c6f-4e3e-9320-58b6ed003c47} executeQuery: Code: 47. DB::Exception: Identifier 'test_table.value_' cannot be resolved from table with name test_table_alias. In scope SELECT test_table.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39154) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT test_table.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:42:16.831920 [ 8101 ] {} TCPHandler: Code: 47. DB::Exception: Identifier 'test_table.value_' cannot be resolved from table with name test_table_alias. In scope SELECT test_table.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:42:16.837394 [ 8431 ] {437237e7-ded9-47c5-ad5c-636e03ad98ed} executeQuery: Code: 42. DB::Exception: Function JSONType requires at least one argument: In scope SELECT JSONType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 65, line 66) (in query: SELECT JSONType();) 2025.06.13 15:42:16.861243 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONType requires at least one argument: In scope SELECT JSONType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:17.008304 [ 8431 ] {09a3dbf5-ab40-410d-8a6d-7030bd49dda2} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 0, should be 1: In scope SELECT JSON_ARRAY_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 66, line 67) (in query: SELECT JSON_ARRAY_LENGTH();) 2025.06.13 15:42:17.030974 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 0, should be 1: In scope SELECT JSON_ARRAY_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:17.113263 [ 8431 ] {b94d5c21-fdf6-46e8-bd7a-57a2f3461a78} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_EXISTS(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 67, line 68) (in query: SELECT JSON_EXISTS();) 2025.06.13 15:42:17.133380 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_EXISTS(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:17.153800 [ 8101 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:17.330845 [ 8431 ] {229c9909-b538-4211-ab70-ba8d2e6d04fb} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_QUERY(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 68, line 69) (in query: SELECT JSON_QUERY();) 2025.06.13 15:42:17.369407 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_QUERY(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:17.389683 [ 7755 ] {9bf99923-9267-411d-acb4-adba775b3814} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_tabl.value_` in scope SELECT test_tabl.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39188) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT test_tabl.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:17.419261 [ 7755 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `test_tabl.value_` in scope SELECT test_tabl.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:17.475358 [ 8431 ] {8e5a2657-a177-4492-9d41-119fee680eb0} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_VALUE(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 69, line 70) (in query: SELECT JSON_VALUE();) 2025.06.13 15:42:17.490698 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_VALUE(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:17.611142 [ 8431 ] {0db9f9a9-908b-4f15-a926-3cac84cc8c4c} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 0, should be 2: In scope SELECT L1Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 70, line 71) (in query: SELECT L1Distance();) 2025.06.13 15:42:17.629548 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 0, should be 2: In scope SELECT L1Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:17.727966 [ 8431 ] {92a99b61-285e-4288-a8a1-ed82c5f0a582} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 0, should be 1: In scope SELECT L1Norm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 71, line 72) (in query: SELECT L1Norm();) 2025.06.13 15:42:17.745422 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 0, should be 1: In scope SELECT L1Norm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:17.831312 [ 8431 ] {ac5ae449-fcd3-4a00-be7b-9b68fb0046b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 0, should be 1: In scope SELECT L1Normalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 72, line 73) (in query: SELECT L1Normalize();) 2025.06.13 15:42:17.840326 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 0, should be 1: In scope SELECT L1Normalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:17.847878 [ 7755 ] {92b14b61-d584-4db7-9846-dd6a1a7147cd} executeQuery: Code: 47. DB::Exception: Identifier 'test_table_alias.value_' cannot be resolved from table with name test_table_alias. In scope SELECT test_table_alias.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_alias.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39234) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT test_table_alias.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:42:17.848745 [ 6952 ] {} test_2gl1zqnb.replace_partition_dest2_2 (b629ef41-1d0a-4107-90f8-af26b168e7d4): Table /test/02271_replace_partition_many/test_2gl1zqnb/dest2/replicas/2 is already started to be removing by another replica right now 2025.06.13 15:42:17.861720 [ 7755 ] {} TCPHandler: Code: 47. DB::Exception: Identifier 'test_table_alias.value_' cannot be resolved from table with name test_table_alias. In scope SELECT test_table_alias.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_alias.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:42:17.993023 [ 8431 ] {6cf4f410-4610-497f-aa50-753eb35425a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 0, should be 2: In scope SELECT L2Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 73, line 74) (in query: SELECT L2Distance();) 2025.06.13 15:42:17.998729 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 0, should be 2: In scope SELECT L2Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:18.084941 [ 8431 ] {3002489a-a528-4020-8c18-f5234919b7f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 0, should be 1: In scope SELECT L2Norm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 74, line 75) (in query: SELECT L2Norm();) 2025.06.13 15:42:18.104645 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 0, should be 1: In scope SELECT L2Norm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:18.203329 [ 8431 ] {35b985d6-43be-42e4-819d-7cf0d4b88888} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 0, should be 1: In scope SELECT L2Normalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 75, line 76) (in query: SELECT L2Normalize();) 2025.06.13 15:42:18.219236 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 0, should be 1: In scope SELECT L2Normalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:18.361245 [ 8431 ] {e740666e-b0d6-4c87-ba41-0f8cacb49f0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 0, should be 2: In scope SELECT L2SquaredDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 76, line 77) (in query: SELECT L2SquaredDistance();) 2025.06.13 15:42:18.369442 [ 9642 ] {f3c010bd-89f4-40d5-941a-42980cc7b9bb} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_table_alia.value_` in scope SELECT test_table_alia.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_alias.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39268) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT test_table_alia.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:18.383664 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 0, should be 2: In scope SELECT L2SquaredDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:18.421064 [ 9642 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `test_table_alia.value_` in scope SELECT test_table_alia.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_alias.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:18.509185 [ 8431 ] {544c99d5-c96f-4561-8147-26cc873b71c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 0, should be 1: In scope SELECT L2SquaredNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 77, line 78) (in query: SELECT L2SquaredNorm();) 2025.06.13 15:42:18.548552 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 0, should be 1: In scope SELECT L2SquaredNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:18.670117 [ 8431 ] {645c1917-d6ca-4e54-9cc3-8830cf4afd25} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT LAST_DAY(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 78, line 79) (in query: SELECT LAST_DAY();) 2025.06.13 15:42:18.690976 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT LAST_DAY(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:18.810593 [ 8431 ] {272d9594-a31f-4487-9aed-dc49d3f9b945} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 0, should be 2: In scope SELECT LinfDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 79, line 80) (in query: SELECT LinfDistance();) 2025.06.13 15:42:18.838936 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 0, should be 2: In scope SELECT LinfDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:18.941658 [ 18615 ] {e9b2eed3-5912-4c56-a4da-b5b7ddd2919a} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `value_` in scope SELECT value_ FROM (SELECT 1 AS value) SETTINGS enable_analyzer = 1. Maybe you meant: ['value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39284) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT value_ FROM (SELECT 1 AS value) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:18.996253 [ 8431 ] {68aee42d-6305-4e93-a227-43f5d96ec74c} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 0, should be 1: In scope SELECT LinfNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 80, line 81) (in query: SELECT LinfNorm();) 2025.06.13 15:42:18.996517 [ 18615 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `value_` in scope SELECT value_ FROM (SELECT 1 AS value) SETTINGS enable_analyzer = 1. Maybe you meant: ['value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:19.016235 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 0, should be 1: In scope SELECT LinfNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:19.038300 [ 9644 ] {f636cb1f-ba88-4b46-ae3d-f73a669738b9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55806) (comment: 02271_replace_partition_many_tables.sql) (in query: DROP DATABASE IF EXISTS test_2gl1zqnb SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:42:19.045586 [ 9644 ] {f636cb1f-ba88-4b46-ae3d-f73a669738b9} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:19.110958 [ 8431 ] {f9cd5b0c-7241-4e13-a8cc-3bc1d1ee315c} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 0, should be 1: In scope SELECT LinfNormalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 81, line 82) (in query: SELECT LinfNormalize();) 2025.06.13 15:42:19.118294 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 0, should be 1: In scope SELECT LinfNormalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:19.219184 [ 8431 ] {6cb22cce-58db-4a0a-b1cc-2714fa20e5ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 0, should be 3: In scope SELECT LpDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 82, line 83) (in query: SELECT LpDistance();) 2025.06.13 15:42:19.229389 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 0, should be 3: In scope SELECT LpDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:19.308369 [ 8431 ] {17c7b258-6200-413a-ba32-bf0834d8c951} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 0, should be 2: In scope SELECT LpNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 83, line 84) (in query: SELECT LpNorm();) 2025.06.13 15:42:19.321303 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 0, should be 2: In scope SELECT LpNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:19.458642 [ 8431 ] {8592afaa-f28b-4486-bd90-c9de13ec44c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 0, should be 2: In scope SELECT LpNormalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 84, line 85) (in query: SELECT LpNormalize();) 2025.06.13 15:42:19.468086 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 0, should be 2: In scope SELECT LpNormalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:19.551941 [ 8431 ] {841d000f-958b-479c-a0ae-475af21002d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 0, should be 1: In scope SELECT MACNumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 85, line 86) (in query: SELECT MACNumToString();) 2025.06.13 15:42:19.590936 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 0, should be 1: In scope SELECT MACNumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:19.616118 [ 18381 ] {9236ed36-bbee-4da2-9d50-7eb2df421058} executeQuery: Code: 47. DB::Exception: Identifier 'subquery.value_' cannot be resolved from subquery with name subquery. In scope SELECT subquery.value_ FROM (SELECT 1 AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39288) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT subquery.value_ FROM (SELECT 1 AS value) AS subquery SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:42:19.625249 [ 18381 ] {} TCPHandler: Code: 47. DB::Exception: Identifier 'subquery.value_' cannot be resolved from subquery with name subquery. In scope SELECT subquery.value_ FROM (SELECT 1 AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:42:19.632192 [ 2957 ] {} test_3.replicated_numbers (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:42:19.636537 [ 2954 ] {} test_13.enum_alter_issue (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:42:19.638080 [ 3004 ] {} test_13.sample_table_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:42:19.639803 [ 3006 ] {} test_sqax1nx4.r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:42:19.641180 [ 3012 ] {} test_9.replicated_report (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:42:19.642978 [ 2998 ] {} test_3.mt_compact (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:42:19.689793 [ 4045 ] {} DatabaseCatalog: Cannot drop table test_2gl1zqnb.replace_partition_dest1 (647528ae-8183-4b55-ba17-9285bdc032ab). Will retry later.: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02271_replace_partition_many/test_2gl1zqnb/dest1/replicas/1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001af98c7c 5. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001af984d0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:555: zkutil::ZooKeeper::tryRemove(String const&, int) @ 0x0000000032758e96 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1459: DB::StorageReplicatedMergeTree::dropReplica(std::shared_ptr, DB::TableZnodeInfo const&, std::shared_ptr, std::shared_ptr, std::optional*) @ 0x00000000305b6e7b 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1382: DB::StorageReplicatedMergeTree::drop() @ 0x00000000305b363a 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d5f99b1 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d607d44 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 12. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:19.778159 [ 8431 ] {a31c91a5-b87b-460b-abf7-a66b91a27234} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 0, should be 1: In scope SELECT MACStringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 86, line 87) (in query: SELECT MACStringToNum();) 2025.06.13 15:42:19.784404 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 0, should be 1: In scope SELECT MACStringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:19.853076 [ 5005 ] {5d639c75-0519-474f-8523-d63f08ad565b} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_2/log/query-0000000434/active/s1|r1. (KEEPER_EXCEPTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48298) (comment: 00705_drop_create_merge_tree.sh) (query 243, line 243) (in query: CREATE TABLE IF NOT EXISTS `table` (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 52589, 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 = 227053708, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 33369451, merge_max_block_size = 1364, old_parts_lifetime = 204., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 83905, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9130827294, index_granularity_bytes = 16692978, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 86, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 88497, primary_key_compress_block_size = 50327, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001af98c7c 5. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001af984d0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:417: zkutil::ZooKeeper::tryCreate(String const&, String const&, int, String&) @ 0x00000000327566bf 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:425: zkutil::ZooKeeper::tryCreate(String const&, String const&, int) @ 0x0000000032756821 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:600: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c2f5d 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 10. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:42:19.892218 [ 5005 ] {} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_2/log/query-0000000434/active/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001af98c7c 5. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001af984d0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:417: zkutil::ZooKeeper::tryCreate(String const&, String const&, int, String&) @ 0x00000000327566bf 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:425: zkutil::ZooKeeper::tryCreate(String const&, String const&, int) @ 0x0000000032756821 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:600: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c2f5d 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 10. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:42:19.958900 [ 8431 ] {2140483e-a548-4005-90ec-dad7b2d3340a} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 0, should be 1: In scope SELECT MACStringToOUI(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 87, line 88) (in query: SELECT MACStringToOUI();) 2025.06.13 15:42:19.966661 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 0, should be 1: In scope SELECT MACStringToOUI(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:20.018620 [ 8431 ] {ac40cdaa-054c-4c22-b205-8ad6992aa6e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 0, should be 2: In scope SELECT MAP_FROM_ARRAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 88, line 89) (in query: SELECT MAP_FROM_ARRAYS();) 2025.06.13 15:42:20.038221 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 0, should be 2: In scope SELECT MAP_FROM_ARRAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:20.143398 [ 3710 ] {14745bfd-5d69-469e-ada8-b9e50f4a61ec} BackupsWorker: Failed to restore from backup Disk('backups', '03145_non_loaded_projection_backup_test_liccri1v'): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=27, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. ./src/IO/ReadBuffer.h:96: DB::(anonymous namespace)::copyDataImpl(DB::ReadBuffer&, DB::WriteBuffer&, bool, unsigned long, std::atomic const*, std::shared_ptr) @ 0x0000000023b772fd 14. ./build_docker/./src/IO/copyData.cpp:82: DB::copyData(DB::ReadBuffer&, DB::WriteBuffer&, unsigned long) @ 0x0000000023b77c2b 15. ./build_docker/./src/Backups/BackupIO_Default.cpp:35: DB::BackupReaderDefault::copyFileToDisk(String const&, unsigned long, bool, std::shared_ptr, String const&, DB::WriteMode) @ 0x000000002bf5eb18 16. ./build_docker/./src/Backups/BackupIO_Disk.cpp:55: DB::BackupReaderDisk::copyFileToDisk(String const&, unsigned long, bool, std::shared_ptr, String const&, DB::WriteMode) @ 0x000000002c06cc52 17. ./build_docker/./src/Backups/BackupImpl.cpp:848: DB::BackupImpl::copyFileToDisk(std::pair> const&, std::shared_ptr, String const&, DB::WriteMode) const @ 0x000000002bf79af0 18. ./build_docker/./src/Backups/BackupImpl.cpp:798: DB::BackupImpl::copyFileToDisk(String const&, std::shared_ptr, String const&, DB::WriteMode) const @ 0x000000002bf79205 19. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6098: DB::MergeTreeData::restorePartFromBackup(std::shared_ptr, DB::MergeTreePartInfo const&, String const&, bool) const @ 0x0000000030d0d5e7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6041: void std::__function::__policy_invoker::__call_impl[abi:ne190107], 7ul, std::allocator>>> const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000030d68fb6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c026f1a 22. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::future std::__function::__policy_invoker (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>::__call_impl[abi:ne190107] (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe&&, char const*)::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority), std::future (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority&&) @ 0x000000002c0265f9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c01946e 6. ./build_docker/./src/Backups/RestorerFromBackup.cpp:1169: DB::RestorerFromBackup::runDataRestoreTasks() @ 0x000000002c01905b 7. ./build_docker/./src/Backups/RestorerFromBackup.cpp:177: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x000000002c0129f9 8. ./build_docker/./src/Backups/BackupsWorker.cpp:948: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf40b09 9. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 10. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 12. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39634 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e48 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:20.150010 [ 5978 ] {14745bfd-5d69-469e-ada8-b9e50f4a61ec} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=27, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39226) (comment: 03145_non_loaded_projection_backup.sh) (query 3, line 4) (in query: restore table tp_1 from Disk('backups', '03145_non_loaded_projection_backup_test_liccri1v');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. ./src/IO/ReadBuffer.h:96: DB::(anonymous namespace)::copyDataImpl(DB::ReadBuffer&, DB::WriteBuffer&, bool, unsigned long, std::atomic const*, std::shared_ptr) @ 0x0000000023b772fd 14. ./build_docker/./src/IO/copyData.cpp:82: DB::copyData(DB::ReadBuffer&, DB::WriteBuffer&, unsigned long) @ 0x0000000023b77c2b 15. ./build_docker/./src/Backups/BackupIO_Default.cpp:35: DB::BackupReaderDefault::copyFileToDisk(String const&, unsigned long, bool, std::shared_ptr, String const&, DB::WriteMode) @ 0x000000002bf5eb18 16. ./build_docker/./src/Backups/BackupIO_Disk.cpp:55: DB::BackupReaderDisk::copyFileToDisk(String const&, unsigned long, bool, std::shared_ptr, String const&, DB::WriteMode) @ 0x000000002c06cc52 17. ./build_docker/./src/Backups/BackupImpl.cpp:848: DB::BackupImpl::copyFileToDisk(std::pair> const&, std::shared_ptr, String const&, DB::WriteMode) const @ 0x000000002bf79af0 18. ./build_docker/./src/Backups/BackupImpl.cpp:798: DB::BackupImpl::copyFileToDisk(String const&, std::shared_ptr, String const&, DB::WriteMode) const @ 0x000000002bf79205 19. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6098: DB::MergeTreeData::restorePartFromBackup(std::shared_ptr, DB::MergeTreePartInfo const&, String const&, bool) const @ 0x0000000030d0d5e7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6041: void std::__function::__policy_invoker::__call_impl[abi:ne190107], 7ul, std::allocator>>> const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000030d68fb6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c026f1a 22. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:42:20.158019 [ 8431 ] {92d0cd24-2dff-4576-838b-5b09a1d570d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 0, should be 1: In scope SELECT MD4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 89, line 90) (in query: SELECT MD4();) 2025.06.13 15:42:20.164047 [ 5978 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=27, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. ./src/IO/ReadBuffer.h:96: DB::(anonymous namespace)::copyDataImpl(DB::ReadBuffer&, DB::WriteBuffer&, bool, unsigned long, std::atomic const*, std::shared_ptr) @ 0x0000000023b772fd 14. ./build_docker/./src/IO/copyData.cpp:82: DB::copyData(DB::ReadBuffer&, DB::WriteBuffer&, unsigned long) @ 0x0000000023b77c2b 15. ./build_docker/./src/Backups/BackupIO_Default.cpp:35: DB::BackupReaderDefault::copyFileToDisk(String const&, unsigned long, bool, std::shared_ptr, String const&, DB::WriteMode) @ 0x000000002bf5eb18 16. ./build_docker/./src/Backups/BackupIO_Disk.cpp:55: DB::BackupReaderDisk::copyFileToDisk(String const&, unsigned long, bool, std::shared_ptr, String const&, DB::WriteMode) @ 0x000000002c06cc52 17. ./build_docker/./src/Backups/BackupImpl.cpp:848: DB::BackupImpl::copyFileToDisk(std::pair> const&, std::shared_ptr, String const&, DB::WriteMode) const @ 0x000000002bf79af0 18. ./build_docker/./src/Backups/BackupImpl.cpp:798: DB::BackupImpl::copyFileToDisk(String const&, std::shared_ptr, String const&, DB::WriteMode) const @ 0x000000002bf79205 19. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6098: DB::MergeTreeData::restorePartFromBackup(std::shared_ptr, DB::MergeTreePartInfo const&, String const&, bool) const @ 0x0000000030d0d5e7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6041: void std::__function::__policy_invoker::__call_impl[abi:ne190107], 7ul, std::allocator>>> const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000030d68fb6 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c026f1a 22. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::future std::__function::__policy_invoker (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>::__call_impl[abi:ne190107] (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe&&, char const*)::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority), std::future (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority&&) @ 0x000000002c0265f9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c01946e 6. ./build_docker/./src/Backups/RestorerFromBackup.cpp:1169: DB::RestorerFromBackup::runDataRestoreTasks() @ 0x000000002c01905b 7. ./build_docker/./src/Backups/RestorerFromBackup.cpp:177: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x000000002c0129f9 8. ./build_docker/./src/Backups/BackupsWorker.cpp:948: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf40b09 9. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 10. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 12. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39634 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e48 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:42:20.173962 [ 2860 ] {8cccbb22-e82e-49b9-ba1d-cd1ce3171427} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `subquer.value_` in scope SELECT subquer.value_ FROM (SELECT 1 AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39306) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT subquer.value_ FROM (SELECT 1 AS value) AS subquery SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:20.192214 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 0, should be 1: In scope SELECT MD4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:20.216912 [ 2860 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `subquer.value_` in scope SELECT subquer.value_ FROM (SELECT 1 AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:20.361029 [ 8431 ] {5575a798-6979-474a-b2b1-b595acb4b073} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 0, should be 1: In scope SELECT MD5(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 90, line 91) (in query: SELECT MD5();) 2025.06.13 15:42:20.370730 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 0, should be 1: In scope SELECT MD5(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:20.523492 [ 8431 ] {52cd0769-1476-4ddc-acd2-6f1d56c0ad27} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT MILLISECOND(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 91, line 92) (in query: SELECT MILLISECOND();) 2025.06.13 15:42:20.551118 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT MILLISECOND(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:20.726620 [ 8431 ] {d6ee413b-29c4-4949-a777-41d9a6791848} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT MINUTE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 92, line 93) (in query: SELECT MINUTE();) 2025.06.13 15:42:20.756841 [ 8442 ] {5d2f72b2-38c2-44e0-82cb-67744ed8cc9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 873, line 874) (in query: SELECT minSampleSizeContinous(NULL, NULL);) 2025.06.13 15:42:20.763502 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT MINUTE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:20.784082 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:20.786095 [ 3821 ] {e52d9adc-b5d1-42ae-b494-2e06300db436} executeQuery: Code: 321. DB::Exception: Value -2208988800 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39256) (comment: 02900_date_time_check_overflow.sql) (query 16, line 23) (in query: SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000230b504f 5. ./src/Functions/FunctionsConversion.h:183: DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x000000002b1a9b52 6. ./src/Functions/TransformDateTime64.h:87: void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b1a9a26 7. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002b1a9363 8. ./src/Functions/FunctionsConversion.h:1311: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1997a2 9. ./src/Core/callOnTypeIndex.h:278: 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&&) @ 0x000000002b02d4b7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0575c2 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b056283 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:20.794695 [ 3821 ] {} TCPHandler: Code: 321. DB::Exception: Value -2208988800 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000230b504f 5. ./src/Functions/FunctionsConversion.h:183: DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x000000002b1a9b52 6. ./src/Functions/TransformDateTime64.h:87: void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b1a9a26 7. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002b1a9363 8. ./src/Functions/FunctionsConversion.h:1311: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1997a2 9. ./src/Core/callOnTypeIndex.h:278: 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&&) @ 0x000000002b02d4b7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0575c2 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b056283 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:20.862063 [ 8430 ] {5380ec90-678f-49d6-bff3-31fd1f8ab637} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `value_` in scope WITH cte_subquery AS (SELECT 1 AS value) SELECT value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39338) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: WITH cte_subquery AS (SELECT 1 AS value) SELECT value_ FROM cte_subquery SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:20.883642 [ 8431 ] {63ca9b12-451d-40f4-aeb5-cb2c37347831} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT MONTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 93, line 94) (in query: SELECT MONTH();) 2025.06.13 15:42:20.906026 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `value_` in scope WITH cte_subquery AS (SELECT 1 AS value) SELECT value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:20.924775 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT MONTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:20.935309 [ 3821 ] {557cd149-2846-4723-bf05-2f1ca9cf93f9} executeQuery: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39256) (comment: 02900_date_time_check_overflow.sql) (query 17, line 24) (in query: SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000230b504f 5. ./src/Functions/FunctionsConversion.h:183: DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x000000002b1a9b52 6. ./src/Functions/TransformDateTime64.h:87: void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b1a9a26 7. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002b1a9363 8. ./src/Functions/FunctionsConversion.h:1311: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1997a2 9. ./src/Core/callOnTypeIndex.h:278: 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&&) @ 0x000000002b02d4b7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0575c2 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b056283 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:20.941451 [ 8442 ] {34b13ef2-a432-41d6-bee7-a439b926c591} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 874, line 875) (in query: SELECT minSampleSizeContinuous(NULL, NULL);) 2025.06.13 15:42:20.957738 [ 3821 ] {} TCPHandler: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type DateTime: In scope SELECT toDateTime(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000230b504f 5. ./src/Functions/FunctionsConversion.h:183: DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x000000002b1a9b52 6. ./src/Functions/TransformDateTime64.h:87: void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b1a9a26 7. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002b1a9363 8. ./src/Functions/FunctionsConversion.h:1311: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1997a2 9. ./src/Core/callOnTypeIndex.h:278: 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&&) @ 0x000000002b02d4b7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0575c2 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b056283 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:20.964085 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:21.015878 [ 8431 ] {5837e2f7-fd59-41f9-b963-4092c3108250} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 0, should be 1: In scope SELECT OCTET_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 94, line 95) (in query: SELECT OCTET_LENGTH();) 2025.06.13 15:42:21.040935 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 0, should be 1: In scope SELECT OCTET_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:21.056027 [ 8442 ] {825bbffa-c06d-4f3d-b31f-515d2e64e9bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 2, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 875, line 876) (in query: SELECT minSampleSizeConversion(NULL, NULL);) 2025.06.13 15:42:21.088263 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 2, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:21.202285 [ 8431 ] {fc9f294b-625a-48eb-8adb-80708865b49c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT QUARTER(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 95, line 96) (in query: SELECT QUARTER();) 2025.06.13 15:42:21.242478 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT QUARTER(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:21.313759 [ 8431 ] {8774e7b2-b363-4148-bf67-9974c654e611} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 0: In scope SELECT REGEXP_EXTRACT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 96, line 97) (in query: SELECT REGEXP_EXTRACT();) 2025.06.13 15:42:21.328351 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 0: In scope SELECT REGEXP_EXTRACT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:21.353099 [ 3821 ] {544fd52c-de41-43e8-ae91-84c26be6ba2d} executeQuery: Code: 321. DB::Exception: Value -25567 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39256) (comment: 02900_date_time_check_overflow.sql) (query 18, line 25) (in query: SELECT toDateTime(toDate32('1900-01-01'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000023e6798f 5. ./src/Functions/FunctionsConversion.h:162: DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(int, DateLUTImpl const&) @ 0x000000002b1a7bc0 6. ./src/Functions/DateTimeTransforms.h:2255: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b1a7a7b 7. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002b1a7423 8. ./src/Functions/FunctionsConversion.h:1183: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b198e23 9. ./src/Core/callOnTypeIndex.h:276: 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&&) @ 0x000000002b02d718 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0575c2 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b056283 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:21.360514 [ 3821 ] {} TCPHandler: Code: 321. DB::Exception: Value -25567 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000023e6798f 5. ./src/Functions/FunctionsConversion.h:162: DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(int, DateLUTImpl const&) @ 0x000000002b1a7bc0 6. ./src/Functions/DateTimeTransforms.h:2255: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b1a7a7b 7. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002b1a7423 8. ./src/Functions/FunctionsConversion.h:1183: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b198e23 9. ./src/Core/callOnTypeIndex.h:276: 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&&) @ 0x000000002b02d718 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0575c2 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b056283 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:21.395158 [ 8431 ] {470c4449-0557-468b-b208-516cca362dc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 0, should be 2: In scope SELECT REGEXP_MATCHES(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 97, line 98) (in query: SELECT REGEXP_MATCHES();) 2025.06.13 15:42:21.400705 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 0, should be 2: In scope SELECT REGEXP_MATCHES(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:21.410787 [ 3821 ] {76ab0b68-62a9-4b79-a700-b35c0d08de38} executeQuery: Code: 321. DB::Exception: Value 120529 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39256) (comment: 02900_date_time_check_overflow.sql) (query 19, line 26) (in query: SELECT toDateTime(toDate32('2299-12-31'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000023e6798f 5. ./src/Functions/FunctionsConversion.h:162: DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(int, DateLUTImpl const&) @ 0x000000002b1a7bc0 6. ./src/Functions/DateTimeTransforms.h:2255: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b1a7a7b 7. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002b1a7423 8. ./src/Functions/FunctionsConversion.h:1183: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b198e23 9. ./src/Core/callOnTypeIndex.h:276: 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&&) @ 0x000000002b02d718 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0575c2 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b056283 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:21.414645 [ 3821 ] {} TCPHandler: Code: 321. DB::Exception: Value 120529 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000023e6798f 5. ./src/Functions/FunctionsConversion.h:162: DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(int, DateLUTImpl const&) @ 0x000000002b1a7bc0 6. ./src/Functions/DateTimeTransforms.h:2255: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b1a7a7b 7. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002b1a7423 8. ./src/Functions/FunctionsConversion.h:1183: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b198e23 9. ./src/Core/callOnTypeIndex.h:276: 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&&) @ 0x000000002b02d718 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0575c2 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b056283 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:21.457515 [ 8430 ] {de6cd452-22d5-4f13-b1e7-fb3c6a2ea804} executeQuery: Code: 47. DB::Exception: Identifier 'cte_subquery.value_' cannot be resolved from subquery. In scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39364) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery.value_ FROM cte_subquery SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:42:21.464991 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Identifier 'cte_subquery.value_' cannot be resolved from subquery. In scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:42:21.489288 [ 8431 ] {38312e50-077f-4f59-b430-529c9609bb8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 0, should be 3: In scope SELECT REGEXP_REPLACE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 98, line 99) (in query: SELECT REGEXP_REPLACE();) 2025.06.13 15:42:21.517820 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 0, should be 3: In scope SELECT REGEXP_REPLACE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:21.622478 [ 8431 ] {562cb4de-a904-40c4-9024-2ea5b9161f2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 0, should be 1: In scope SELECT RIPEMD160(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 99, line 100) (in query: SELECT RIPEMD160();) 2025.06.13 15:42:21.656078 [ 3821 ] {406161a8-8fde-4d03-b8fd-0a6cddb78dcf} executeQuery: Code: 321. DB::Exception: Day number 65535 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate('2149-06-06')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39256) (comment: 02900_date_time_check_overflow.sql) (query 20, line 27) (in query: SELECT toDateTime(toDate('2149-06-06'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned short&) @ 0x00000000239d408f 5. ./src/Functions/FunctionsConversion.h:141: DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(unsigned short, DateLUTImpl const&) @ 0x000000002b1a5ceb 6. ./src/Functions/DateTimeTransforms.h:2255: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b1a5b94 7. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002b1a5563 8. ./src/Functions/FunctionsConversion.h:1183: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b198b03 9. ./src/Core/callOnTypeIndex.h:275: 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&&) @ 0x000000002b02d67c 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0575c2 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b056283 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:21.656076 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 0, should be 1: In scope SELECT RIPEMD160(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:21.673320 [ 3821 ] {} TCPHandler: Code: 321. DB::Exception: Day number 65535 is out of bounds of type DateTime: In scope SELECT toDateTime(toDate('2149-06-06')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned short&) @ 0x00000000239d408f 5. ./src/Functions/FunctionsConversion.h:141: DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(unsigned short, DateLUTImpl const&) @ 0x000000002b1a5ceb 6. ./src/Functions/DateTimeTransforms.h:2255: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b1a5b94 7. ./src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002b1a5563 8. ./src/Functions/FunctionsConversion.h:1183: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b198b03 9. ./src/Core/callOnTypeIndex.h:275: 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&&) @ 0x000000002b02d67c 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0575c2 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b056283 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:22.036323 [ 8431 ] {d76906ba-ff09-400d-aa45-fb2bd3df6b3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT SECOND(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 101, line 102) (in query: SELECT SECOND();) 2025.06.13 15:42:22.037389 [ 2860 ] {55c9cd65-4005-4285-825a-471c92ae1f43} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `cte_subquer.value_` in scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquer.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39378) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquer.value_ FROM cte_subquery SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:22.046560 [ 3821 ] {eb134e3f-cdc3-4b00-a66b-39ec27d72b37} executeQuery: Code: 321. DB::Exception: Value -2208988799 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39256) (comment: 02900_date_time_check_overflow.sql) (query 21, line 28) (in query: SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000230b504f 5. ./src/Functions/DateTimeTransforms.h:97: DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x000000002b154332 6. ./src/Functions/DateTimeTransforms.h:82: void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b15419f 7. ./src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002b153c06 8. ./src/Functions/FunctionsConversion.h:1305: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b143e42 9. ./src/Core/callOnTypeIndex.h:278: 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&&) @ 0x000000002b02ceb7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05273e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0515a3 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:22.069802 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT SECOND(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:22.091026 [ 2860 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `cte_subquer.value_` in scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquer.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:22.104058 [ 3821 ] {} TCPHandler: Code: 321. DB::Exception: Value -2208988799 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('1900-01-01 00:00:00.123', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000230b504f 5. ./src/Functions/DateTimeTransforms.h:97: DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x000000002b154332 6. ./src/Functions/DateTimeTransforms.h:82: void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b15419f 7. ./src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002b153c06 8. ./src/Functions/FunctionsConversion.h:1305: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b143e42 9. ./src/Core/callOnTypeIndex.h:278: 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&&) @ 0x000000002b02ceb7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05273e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0515a3 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:22.240605 [ 8431 ] {c1a628cf-8e22-4773-a830-f309d20195d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 0, should be 1: In scope SELECT SHA1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 102, line 103) (in query: SELECT SHA1();) 2025.06.13 15:42:22.260760 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 0, should be 1: In scope SELECT SHA1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:22.265464 [ 3821 ] {af1118e0-73cb-4992-8244-f92e71c3fa29} executeQuery: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39256) (comment: 02900_date_time_check_overflow.sql) (query 22, line 29) (in query: SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000230b504f 5. ./src/Functions/DateTimeTransforms.h:97: DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x000000002b154332 6. ./src/Functions/DateTimeTransforms.h:82: void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b15419f 7. ./src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002b153c06 8. ./src/Functions/FunctionsConversion.h:1305: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b143e42 9. ./src/Core/callOnTypeIndex.h:278: 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&&) @ 0x000000002b02ceb7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05273e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0515a3 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:22.280673 [ 3821 ] {} TCPHandler: Code: 321. DB::Exception: Value 10413791999 is out of bounds of type Date: In scope SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 3)). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&) @ 0x00000000230b504f 5. ./src/Functions/DateTimeTransforms.h:97: DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(long, DateLUTImpl const&) @ 0x000000002b154332 6. ./src/Functions/DateTimeTransforms.h:82: void DB::Transformer>, false, unsigned int>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::TransformDateTime64> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b15419f 7. ./src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr DB::DateTimeTransformImpl>, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::TransformDateTime64> const&) @ 0x000000002b153c06 8. ./src/Functions/FunctionsConversion.h:1305: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b143e42 9. ./src/Core/callOnTypeIndex.h:278: 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&&) @ 0x000000002b02ceb7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05273e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0515a3 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:22.407667 [ 8431 ] {e65778a7-fe55-46e8-8df0-1fbf0d71a587} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 0, should be 1: In scope SELECT SHA224(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 103, line 104) (in query: SELECT SHA224();) 2025.06.13 15:42:22.414602 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 0, should be 1: In scope SELECT SHA224(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:22.549098 [ 8431 ] {c361e4ee-f820-4803-9211-e4675a79bf50} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 0, should be 1: In scope SELECT SHA256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 104, line 105) (in query: SELECT SHA256();) 2025.06.13 15:42:22.564198 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 0, should be 1: In scope SELECT SHA256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:22.597254 [ 8442 ] {df9391fe-88ef-4386-8c3a-eb2c71071051} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 2, should be 1: In scope SELECT monthName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 882, line 883) (in query: SELECT monthName(NULL, NULL);) 2025.06.13 15:42:22.622220 [ 3821 ] {6b19b497-11f2-45f1-8f93-fad1e7700e2b} executeQuery: Code: 321. DB::Exception: Value -25567 is out of bounds of type Date: In scope SELECT toDate(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39256) (comment: 02900_date_time_check_overflow.sql) (query 23, line 30) (in query: SELECT toDate(toDate32('1900-01-01'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000023e6798f 5. ./src/Functions/DateTimeTransforms.h:117: DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(int, DateLUTImpl const&) @ 0x000000002b15056b 6. ./src/Functions/DateTimeTransforms.h:2255: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b15045d 7. ./src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002b14ff26 8. ./src/Functions/FunctionsConversion.h:1170: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b143443 9. ./src/Core/callOnTypeIndex.h:276: 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&&) @ 0x000000002b02d118 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05273e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0515a3 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:22.632188 [ 2860 ] {ef524aa2-9919-4039-acf5-1a5f5da87ac7} executeQuery: Code: 47. DB::Exception: Identifier 'cte_subquery_alias.value_' cannot be resolved from subquery with name cte_subquery_alias. In scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery_alias.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39414) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery_alias.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:42:22.635708 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 2, should be 1: In scope SELECT monthName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:22.642780 [ 3821 ] {} TCPHandler: Code: 321. DB::Exception: Value -25567 is out of bounds of type Date: In scope SELECT toDate(toDate32('1900-01-01')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000023e6798f 5. ./src/Functions/DateTimeTransforms.h:117: DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(int, DateLUTImpl const&) @ 0x000000002b15056b 6. ./src/Functions/DateTimeTransforms.h:2255: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b15045d 7. ./src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002b14ff26 8. ./src/Functions/FunctionsConversion.h:1170: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b143443 9. ./src/Core/callOnTypeIndex.h:276: 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&&) @ 0x000000002b02d118 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05273e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0515a3 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:22.676757 [ 2860 ] {} TCPHandler: Code: 47. DB::Exception: Identifier 'cte_subquery_alias.value_' cannot be resolved from subquery with name cte_subquery_alias. In scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery_alias.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:42:22.686595 [ 8431 ] {b7a9cb75-5436-4a31-8629-df9bdedbb1ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 0, should be 1: In scope SELECT SHA384(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 105, line 106) (in query: SELECT SHA384();) 2025.06.13 15:42:22.701317 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 0, should be 1: In scope SELECT SHA384(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:22.772712 [ 3821 ] {8a4316a9-7257-4506-a019-65373c4f0d04} executeQuery: Code: 321. DB::Exception: Value 120529 is out of bounds of type Date: In scope SELECT toDate(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39256) (comment: 02900_date_time_check_overflow.sql) (query 24, line 31) (in query: SELECT toDate(toDate32('2299-12-31'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000023e6798f 5. ./src/Functions/DateTimeTransforms.h:117: DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(int, DateLUTImpl const&) @ 0x000000002b15056b 6. ./src/Functions/DateTimeTransforms.h:2255: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b15045d 7. ./src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002b14ff26 8. ./src/Functions/FunctionsConversion.h:1170: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b143443 9. ./src/Core/callOnTypeIndex.h:276: 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&&) @ 0x000000002b02d118 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05273e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0515a3 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:22.779932 [ 3821 ] {} TCPHandler: Code: 321. DB::Exception: Value 120529 is out of bounds of type Date: In scope SELECT toDate(toDate32('2299-12-31')). (VALUE_IS_OUT_OF_RANGE_OF_DATA_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, int&) @ 0x0000000023e6798f 5. ./src/Functions/DateTimeTransforms.h:117: DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1>::execute(int, DateLUTImpl const&) @ 0x000000002b15056b 6. ./src/Functions/DateTimeTransforms.h:2255: void DB::Transformer, false, void*>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x000000002b15045d 7. ./src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr DB::DateTimeTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDateImpl<(DB::FormatSettings::DateTimeOverflowBehavior)1> const&) @ 0x000000002b14ff26 8. ./src/Functions/FunctionsConversion.h:1170: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b143443 9. ./src/Core/callOnTypeIndex.h:276: 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&&) @ 0x000000002b02d118 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05273e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0515a3 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:42:22.928309 [ 8431 ] {9cf186cd-d5ed-448f-b6a2-047b98594af9} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 0, should be 1: In scope SELECT SHA512(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 106, line 107) (in query: SELECT SHA512();) 2025.06.13 15:42:22.942908 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 0, should be 1: In scope SELECT SHA512(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:23.078001 [ 8431 ] {ecd033d5-8028-46a7-b5e2-50ba09db578e} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 0, should be 1: In scope SELECT SHA512_256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 107, line 108) (in query: SELECT SHA512_256();) 2025.06.13 15:42:23.101633 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 0, should be 1: In scope SELECT SHA512_256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:23.123416 [ 8442 ] {fd414eb2-5a58-4cf1-9ae5-fee4860c28e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAllIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 885, line 886) (in query: SELECT multiFuzzyMatchAllIndices(NULL, NULL);) 2025.06.13 15:42:23.131058 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAllIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:23.213271 [ 8431 ] {eea4d5c5-8473-40e7-9221-4c912b8b0dd6} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 108, line 109) (in query: SELECT STD();) 2025.06.13 15:42:23.239176 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:23.242735 [ 8442 ] {9c63e405-f727-4f0d-91cd-87466376126f} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAny(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 886, line 887) (in query: SELECT multiFuzzyMatchAny(NULL, NULL);) 2025.06.13 15:42:23.251350 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAny(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:23.281116 [ 18510 ] {129b6544-19de-4a73-9e8b-71476576e27b} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `cte_subquery_alia.value_` in scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery_alia.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39440) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery_alia.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:23.309227 [ 18510 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `cte_subquery_alia.value_` in scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery_alia.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:23.361696 [ 8431 ] {c35fbbac-ef0a-41ab-8a4a-200cf26146f3} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 109, line 110) (in query: SELECT STDDEV_POP();) 2025.06.13 15:42:23.371328 [ 8442 ] {d8f0c24f-c7c5-49ef-a0b8-de303156cfff} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 887, line 888) (in query: SELECT multiFuzzyMatchAnyIndex(NULL, NULL);) 2025.06.13 15:42:23.401525 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:23.406667 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:23.533532 [ 8431 ] {bab4eb4e-e702-4938-b771-fdb1cd264252} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 110, line 111) (in query: SELECT STDDEV_SAMP();) 2025.06.13 15:42:23.563388 [ 8442 ] {8787192d-8740-4b83-9234-7f8f90f932ce} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 888, line 889) (in query: SELECT multiIf(NULL, NULL);) 2025.06.13 15:42:23.563721 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:23.590340 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:23.651412 [ 8431 ] {20a0372d-21b3-4e45-8fcf-79d3d9da31a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 0, should be 3: In scope SELECT SUBSTRING_INDEX(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 111, line 112) (in query: SELECT SUBSTRING_INDEX();) 2025.06.13 15:42:23.667327 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 0, should be 3: In scope SELECT SUBSTRING_INDEX(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:23.705235 [ 18381 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:23.798997 [ 8431 ] {8c68d4b3-d944-4d36-9663-9644b8a4a56c} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT SVG(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 112, line 113) (in query: SELECT SVG();) 2025.06.13 15:42:23.805062 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT SVG(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:23.830443 [ 8430 ] {188f773b-046a-4f50-aded-769628612c79} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `constant_valu` in scope SELECT 1 AS constant_value, constant_valu SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56190) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT 1 AS constant_value, constant_valu SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:23.896447 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `constant_valu` in scope SELECT 1 AS constant_value, constant_valu SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:23.940594 [ 8431 ] {8b39e86c-0e58-4854-9435-e75b4c5d3064} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 113, line 114) (in query: SELECT TIMESTAMP_DIFF();) 2025.06.13 15:42:23.942500 [ 9642 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:23.963828 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:24.164393 [ 8431 ] {006cb0fb-b5cb-4eca-91dd-67f0e210a8f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 0, should be 1: In scope SELECT TO_BASE64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 114, line 115) (in query: SELECT TO_BASE64();) 2025.06.13 15:42:24.186285 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 0, should be 1: In scope SELECT TO_BASE64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:24.271065 [ 18381 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:24.310040 [ 8431 ] {cff76c42-892c-4040-9037-e891fb09cdaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT TO_DAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 115, line 116) (in query: SELECT TO_DAYS();) 2025.06.13 15:42:24.323433 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT TO_DAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:24.384352 [ 18510 ] {512d9aba-206d-4bf3-b7e8-9fdf365ec427} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `constant_valu` in scope SELECT 1 AS constant_value, constant_valu SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56206) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT 1 AS constant_value, constant_valu SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:24.404409 [ 8431 ] {02283814-551c-4614-a7dd-f9286d711eae} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT TO_UNIXTIME(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 116, line 117) (in query: SELECT TO_UNIXTIME();) 2025.06.13 15:42:24.436543 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT TO_UNIXTIME(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:24.445030 [ 18510 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `constant_valu` in scope SELECT 1 AS constant_value, constant_valu SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:24.572491 [ 8431 ] {514fbdd6-e893-48cc-a32d-cce3531ffbc7} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function ULIDStringToDateTime: should be 1 or 2: In scope SELECT ULIDStringToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 117, line 118) (in query: SELECT ULIDStringToDateTime();) 2025.06.13 15:42:24.597214 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function ULIDStringToDateTime: should be 1 or 2: In scope SELECT ULIDStringToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:24.693306 [ 8431 ] {9e841e1d-285d-4f5a-afd0-a1d7ae8713cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHash doesn't match: passed 0, should be 1 or 2.: In scope SELECT URLHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 118, line 119) (in query: SELECT URLHash();) 2025.06.13 15:42:24.713955 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHash doesn't match: passed 0, should be 1 or 2.: In scope SELECT URLHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:24.843457 [ 8431 ] {c258d908-45c6-426f-b7b6-01b9386c12de} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 0, should be 1: In scope SELECT URLHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 119, line 120) (in query: SELECT URLHierarchy();) 2025.06.13 15:42:24.893812 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 0, should be 1: In scope SELECT URLHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:25.020402 [ 8431 ] {50c80f0c-aa09-41d3-b7ff-afddfb3875b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 0, should be 1: In scope SELECT URLPathHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 120, line 121) (in query: SELECT URLPathHierarchy();) 2025.06.13 15:42:25.038112 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 0, should be 1: In scope SELECT URLPathHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:25.184073 [ 8430 ] {c7195692-6ea8-40ac-b784-34970ca6eee1} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `constant_valu` in scope lambda_argument -> (lambda_argument + constant_valu). Maybe you meant: ['constant_value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56228) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT 1 AS constant_value, arrayMap(lambda_argument -> lambda_argument + constant_valu, [1, 2, 3]) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc42299 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3434: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2e7c8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:25.219955 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `constant_valu` in scope lambda_argument -> (lambda_argument + constant_valu). Maybe you meant: ['constant_value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc42299 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3434: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2e7c8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:25.589995 [ 8431 ] {0149c090-6296-4e2b-a45c-3a82ab6e47c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDNumToString doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDNumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 123, line 124) (in query: SELECT UUIDNumToString();) 2025.06.13 15:42:25.602213 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDNumToString doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDNumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:25.706233 [ 8431 ] {827fae10-3b05-44b9-b8a6-3337f57c35bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDStringToNum doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDStringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 124, line 125) (in query: SELECT UUIDStringToNum();) 2025.06.13 15:42:25.895102 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDStringToNum doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDStringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:25.912800 [ 18511 ] {d75e9953-1db7-438c-9888-b87c196dc8bb} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `constant_valu` in scope (SELECT constant_valu). Maybe you meant: ['constant_value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56268) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: WITH 1 AS constant_value SELECT (SELECT constant_valu) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:42:25.957873 [ 18511 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `constant_valu` in scope (SELECT constant_valu). Maybe you meant: ['constant_value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:42:25.960776 [ 8431 ] {cf36cfce-401f-48f3-ad9f-9f23ba28e7e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDToNum doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 125, line 126) (in query: SELECT UUIDToNum();) 2025.06.13 15:42:25.994058 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDToNum doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:26.194205 [ 8431 ] {4512e87c-375a-4ecf-9cc3-5fa3830e2f4b} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function UUIDv7ToDateTime: should be 1 or 2: In scope SELECT UUIDv7ToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 126, line 127) (in query: SELECT UUIDv7ToDateTime();) 2025.06.13 15:42:26.233522 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function UUIDv7ToDateTime: should be 1 or 2: In scope SELECT UUIDv7ToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:26.345301 [ 8431 ] {40bf489e-3dd7-4a0d-9dc7-d8e66a00d3c7} executeQuery: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 127, line 128) (in query: SELECT VAR_POP();) 2025.06.13 15:42:26.368785 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:26.466593 [ 8431 ] {3edfd66c-f6a8-40af-901b-4966c415fb60} executeQuery: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 128, line 129) (in query: SELECT VAR_SAMP();) 2025.06.13 15:42:26.496990 [ 18510 ] {71b9432b-2bf5-427a-a4b4-c13f61441f2a} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a ORC format file. Error: std::exception. Code: 1001, type: orc::ParseError, e.what() = Footer is corrupt: STRUCT type 0 has 3 subTypes, but has 2 fieldNames (version 25.3.3.20286.altinityantalya (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/corrupted.orc). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56276) (comment: 02185_orc_corrupted_file.sh) (query 1, line 1) (in query: select * from file('corrupted.orc')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076c88f 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c05bc 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1a90 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303d1c6d 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303d2624 9. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000303d41da 10. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000303d5926 11. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000303d6177 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageFile* std::construct_at[abi:ne190107](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284ca20b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284ca043 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284c9e74 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284c7039 16. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 18. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:26.499411 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:26.533430 [ 18510 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a ORC format file. Error: std::exception. Code: 1001, type: orc::ParseError, e.what() = Footer is corrupt: STRUCT type 0 has 3 subTypes, but has 2 fieldNames (version 25.3.3.20286.altinityantalya (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/corrupted.orc). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000002076c88f 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c05bc 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1a90 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303d1c6d 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000303d2624 9. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x00000000303d41da 10. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000303d5926 11. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000303d6177 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageFile* std::construct_at[abi:ne190107](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284ca20b 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284ca043 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284c9e74 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284c7039 16. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 18. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:42:26.627858 [ 8431 ] {dfcec98c-b985-415d-8a0c-654ad8ddd985} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 0, should be 1 or 2: In scope SELECT YEAR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 129, line 130) (in query: SELECT YEAR();) 2025.06.13 15:42:26.636694 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 0, should be 1 or 2: In scope SELECT YEAR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:26.774900 [ 8431 ] {7133da71-efc2-4933-90dc-cbf39bd66fcc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 130, line 131) (in query: SELECT YYYYMMDDToDate();) 2025.06.13 15:42:26.789708 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:26.885576 [ 8431 ] {c1c5e158-9a04-4a41-a4c7-42aae8bd755d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 131, line 132) (in query: SELECT YYYYMMDDToDate32();) 2025.06.13 15:42:26.890662 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:26.994867 [ 8431 ] {082a7416-35b4-4b8d-ab67-c51de13a0ffe} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 132, line 133) (in query: SELECT YYYYMMDDhhmmssToDateTime();) 2025.06.13 15:42:27.007285 [ 8431 ] {} 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) 2025.06.13 15:42:27.154516 [ 8431 ] {6c46ea5e-8e87-4d61-871f-40dcddfacfc4} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 133, line 134) (in query: SELECT YYYYMMDDhhmmssToDateTime64();) 2025.06.13 15:42:27.176292 [ 8431 ] {} 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) 2025.06.13 15:42:27.301631 [ 8431 ] {b0aa1557-db65-41b1-9b80-cf65690bf88e} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 0, should be 2: In scope SELECT _CAST(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 134, line 135) (in query: SELECT _CAST();) 2025.06.13 15:42:27.320125 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 0, should be 2: In scope SELECT _CAST(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:27.453705 [ 8431 ] {73380ca3-231e-41ba-8ac8-cb6d4cf72d4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 0, should be 2: In scope SELECT __actionName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 135, line 136) (in query: SELECT __actionName();) 2025.06.13 15:42:27.469569 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 0, should be 2: In scope SELECT __actionName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:27.545368 [ 8431 ] {41895772-db3f-4918-aeb2-87921f0d2bc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 0, should be 2: In scope SELECT __bitBoolMaskAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 136, line 137) (in query: SELECT __bitBoolMaskAnd();) 2025.06.13 15:42:27.554321 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 0, should be 2: In scope SELECT __bitBoolMaskAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:27.608221 [ 18511 ] {895b0977-bcab-4dcb-a51c-978ace60d59e} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `value.value_` in scope SELECT value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1. Maybe you meant: ['value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56316) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:27.637322 [ 8431 ] {1a45060d-cbdb-4423-b9da-ed7d0dd88664} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 0, should be 2: In scope SELECT __bitBoolMaskOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 137, line 138) (in query: SELECT __bitBoolMaskOr();) 2025.06.13 15:42:27.656873 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 0, should be 2: In scope SELECT __bitBoolMaskOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:27.725658 [ 18511 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `value.value_` in scope SELECT value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1. Maybe you meant: ['value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:27.803738 [ 8431 ] {03dcacc0-fcf8-44f6-b4b8-8829945e4c33} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 0, should be 1: In scope SELECT __bitSwapLastTwo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 138, line 139) (in query: SELECT __bitSwapLastTwo();) 2025.06.13 15:42:27.828569 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 0, should be 1: In scope SELECT __bitSwapLastTwo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:27.899996 [ 8431 ] {0e06b386-3a03-47ed-bb92-28cf86950844} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 0, should be 1: In scope SELECT __bitWrapperFunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 139, line 140) (in query: SELECT __bitWrapperFunc();) 2025.06.13 15:42:27.916302 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 0, should be 1: In scope SELECT __bitWrapperFunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:28.016687 [ 8431 ] {ad459ef1-27e4-4970-9e5f-83e4c55a7248} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 0, should be 1: In scope SELECT __getScalar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 140, line 141) (in query: SELECT __getScalar();) 2025.06.13 15:42:28.036974 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 0, should be 1: In scope SELECT __getScalar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:28.213006 [ 8431 ] {63e7672a-2395-4839-ac36-063090df7e5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 0, should be 1: In scope SELECT __scalarSubqueryResult(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 141, line 142) (in query: SELECT __scalarSubqueryResult();) 2025.06.13 15:42:28.218247 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 0, should be 1: In scope SELECT __scalarSubqueryResult(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:28.343810 [ 8431 ] {8899c6e5-5f74-49e1-a438-09abf9e815a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 0, should be 1: In scope SELECT abs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 142, line 143) (in query: SELECT abs();) 2025.06.13 15:42:28.364798 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 0, should be 1: In scope SELECT abs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:28.468543 [ 18510 ] {7cd08158-76c6-465d-a998-df10b1387e37} executeQuery: Code: 47. DB::Exception: Identifier test_table_compound.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from table with name test_13.test_table_compound. In scope SELECT test_table_compound.value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56342) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT test_table_compound.value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x000000002d1467f7 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:257: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000002d13617b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:526: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d1394e1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:28.500009 [ 18510 ] {} TCPHandler: Code: 47. DB::Exception: Identifier test_table_compound.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from table with name test_13.test_table_compound. In scope SELECT test_table_compound.value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x000000002d1467f7 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:257: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000002d13617b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:526: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d1394e1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:28.500072 [ 8431 ] {a3dc75eb-507e-49f2-a66c-267d644ebb94} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 0, should be 2: In scope SELECT accurateCast(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 143, line 144) (in query: SELECT accurateCast();) 2025.06.13 15:42:28.525943 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 0, should be 2: In scope SELECT accurateCast(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:28.703306 [ 8431 ] {76150d91-4d3e-498d-831b-d1e4e884573c} executeQuery: Code: 42. DB::Exception: Function accurateCastOrDefault expected 2 or 3 arguments. Actual 0: In scope SELECT accurateCastOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 144, line 145) (in query: SELECT accurateCastOrDefault();) 2025.06.13 15:42:28.714082 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function accurateCastOrDefault expected 2 or 3 arguments. Actual 0: In scope SELECT accurateCastOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:28.787400 [ 8431 ] {0a7c0c16-b9d8-4787-996d-f8181d570cd0} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 0, should be 2: In scope SELECT accurateCastOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 145, line 146) (in query: SELECT accurateCastOrNull();) 2025.06.13 15:42:28.807395 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 0, should be 2: In scope SELECT accurateCastOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:28.896865 [ 8431 ] {6d781af2-3d4f-4b9f-bda9-d4c2546f95e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 0, should be 1: In scope SELECT acos(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 146, line 147) (in query: SELECT acos();) 2025.06.13 15:42:28.905106 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 0, should be 1: In scope SELECT acos(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:28.953438 [ 8101 ] {0b9dc79b-5a51-4240-9a75-4415af1621f3} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_tabl_compound.value.value_` in scope SELECT test_tabl_compound.value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56362) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT test_tabl_compound.value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:28.959011 [ 8431 ] {0283d85b-cf6d-404c-a16e-940a7882c56c} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 0, should be 1: In scope SELECT acosh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 147, line 148) (in query: SELECT acosh();) 2025.06.13 15:42:28.981612 [ 8101 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `test_tabl_compound.value.value_` in scope SELECT test_tabl_compound.value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:28.985285 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 0, should be 1: In scope SELECT acosh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:29.092291 [ 8431 ] {f0a99c40-15ce-4214-8149-3d787e233c2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 0, should be 2: In scope SELECT addDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 148, line 149) (in query: SELECT addDate();) 2025.06.13 15:42:29.121582 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 0, should be 2: In scope SELECT addDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:29.164393 [ 8442 ] {6025d7f4-3929-45c0-b452-0ce21fbffd00} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 2, should be 1: In scope SELECT negate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 915, line 916) (in query: SELECT negate(NULL, NULL);) 2025.06.13 15:42:29.195884 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 2, should be 1: In scope SELECT negate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:29.270895 [ 8431 ] {7f196f39-e884-4447-9c11-d45482f3398c} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDays doesn't match: passed 0, should be 2 or 3: In scope SELECT addDays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 149, line 150) (in query: SELECT addDays();) 2025.06.13 15:42:29.300870 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDays doesn't match: passed 0, should be 2 or 3: In scope SELECT addDays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:29.316065 [ 8442 ] {f783d634-7cf7-4b74-9719-95a319a2f02c} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 916, line 917) (in query: SELECT neighbor(NULL, NULL);) 2025.06.13 15:42:29.363275 [ 8442 ] {} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:42:29.442022 [ 8431 ] {61e19d18-686d-4a3c-bf45-2f2081eec53c} executeQuery: Code: 42. DB::Exception: Number of arguments for function addHours doesn't match: passed 0, should be 2 or 3: In scope SELECT addHours(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 150, line 151) (in query: SELECT addHours();) 2025.06.13 15:42:29.464774 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addHours doesn't match: passed 0, should be 2 or 3: In scope SELECT addHours(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:29.553899 [ 18510 ] {031d32bb-8f77-44d8-a83c-10c28ba10933} executeQuery: Code: 47. DB::Exception: Identifier test_table_compound.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from table with name test_table_compound_alias. In scope SELECT test_table_compound.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56378) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT test_table_compound.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x000000002d1467f7 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:257: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000002d13617b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:526: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d1394e1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:29.577163 [ 18510 ] {} TCPHandler: Code: 47. DB::Exception: Identifier test_table_compound.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from table with name test_table_compound_alias. In scope SELECT test_table_compound.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x000000002d1467f7 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:257: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000002d13617b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:526: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d1394e1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:29.592062 [ 8431 ] {45a2713e-aa83-4c58-98e2-be1caaf4edf5} executeQuery: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 0, should be 2: In scope SELECT addInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 151, line 152) (in query: SELECT addInterval();) 2025.06.13 15:42:29.614536 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 0, should be 2: In scope SELECT addInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:29.677038 [ 8442 ] {40be6da3-d88d-4978-a8c4-2616d9decfca} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 2, should be 1: In scope SELECT netloc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 918, line 919) (in query: SELECT netloc(NULL, NULL);) 2025.06.13 15:42:29.694048 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 2, should be 1: In scope SELECT netloc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:29.829530 [ 8431 ] {033537a5-0039-447c-b23c-4759c1a29b95} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMicroseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addMicroseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 152, line 153) (in query: SELECT addMicroseconds();) 2025.06.13 15:42:29.836839 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMicroseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addMicroseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:30.032534 [ 8431 ] {62dba64e-b127-4b67-a1d2-c64024135fe6} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMilliseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addMilliseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 153, line 154) (in query: SELECT addMilliseconds();) 2025.06.13 15:42:30.037539 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMilliseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addMilliseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:30.132181 [ 8431 ] {94eea5e7-898f-4e2b-b9e2-a8c8026df67d} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMinutes doesn't match: passed 0, should be 2 or 3: In scope SELECT addMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 154, line 155) (in query: SELECT addMinutes();) 2025.06.13 15:42:30.145556 [ 8101 ] {f5fcc43f-1113-4f8d-9367-21fca752a1b7} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_tabl_compound.value.value_` in scope SELECT test_tabl_compound.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56392) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT test_tabl_compound.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:30.151116 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMinutes doesn't match: passed 0, should be 2 or 3: In scope SELECT addMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:30.177290 [ 8101 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `test_tabl_compound.value.value_` in scope SELECT test_tabl_compound.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:30.248165 [ 8431 ] {c0670fed-2521-456f-b223-2c183bd3d4a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMonths doesn't match: passed 0, should be 2 or 3: In scope SELECT addMonths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 155, line 156) (in query: SELECT addMonths();) 2025.06.13 15:42:30.271441 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMonths doesn't match: passed 0, should be 2 or 3: In scope SELECT addMonths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:30.386060 [ 8431 ] {9be87dd6-cf32-414e-aad9-6069ec325eb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function addNanoseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addNanoseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 156, line 157) (in query: SELECT addNanoseconds();) 2025.06.13 15:42:30.440071 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addNanoseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addNanoseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:30.548986 [ 8431 ] {dc652b71-bd82-4d80-acfc-41a527d40037} executeQuery: Code: 42. DB::Exception: Number of arguments for function addQuarters doesn't match: passed 0, should be 2 or 3: In scope SELECT addQuarters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 157, line 158) (in query: SELECT addQuarters();) 2025.06.13 15:42:30.566541 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addQuarters doesn't match: passed 0, should be 2 or 3: In scope SELECT addQuarters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:30.627646 [ 8431 ] {ab00d1d7-a716-4521-910d-808852352e08} executeQuery: Code: 42. DB::Exception: Number of arguments for function addSeconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addSeconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 158, line 159) (in query: SELECT addSeconds();) 2025.06.13 15:42:30.679611 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addSeconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addSeconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:30.687335 [ 5978 ] {b2506d7a-103c-4b8d-8886-fdb870952671} executeQuery: Code: 47. DB::Exception: Identifier test_table_compound_alias.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from table with name test_table_compound_alias. In scope SELECT test_table_compound_alias.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound_alias.value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56414) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT test_table_compound_alias.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x000000002d1467f7 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:257: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000002d13617b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:526: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d1394e1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:30.723751 [ 5978 ] {} TCPHandler: Code: 47. DB::Exception: Identifier test_table_compound_alias.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from table with name test_table_compound_alias. In scope SELECT test_table_compound_alias.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound_alias.value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x000000002d1467f7 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:257: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000002d13617b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:526: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d1394e1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:30.889695 [ 8431 ] {39f560cc-a558-40cb-a3ff-3f509c02fb01} executeQuery: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 0, should be 2: In scope SELECT addTupleOfIntervals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 159, line 160) (in query: SELECT addTupleOfIntervals();) 2025.06.13 15:42:30.903740 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 0, should be 2: In scope SELECT addTupleOfIntervals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:30.931473 [ 6234 ] {5674dbe3-3307-420a-bb3c-3b5360d59c42} 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.20286.altinityantalya (altinity build)) (from [::1]:56348) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 9, line 13) (in query: -- constant ignore will be pruned by part pruner. ignore(*) is used. SELECT count() FROM merge_tree WHERE not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003218d1b0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0c69 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:42:30.947368 [ 6234 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003218d1b0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0c69 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:42:31.006931 [ 8431 ] {008dbcc9-d718-4243-aad2-0aaf15c446e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function addWeeks doesn't match: passed 0, should be 2 or 3: In scope SELECT addWeeks(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 160, line 161) (in query: SELECT addWeeks();) 2025.06.13 15:42:31.023499 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addWeeks doesn't match: passed 0, should be 2 or 3: In scope SELECT addWeeks(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:31.155391 [ 8431 ] {25d43e16-4622-46b5-9eb3-a6c98fb68705} executeQuery: Code: 42. DB::Exception: Number of arguments for function addYears doesn't match: passed 0, should be 2 or 3: In scope SELECT addYears(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 161, line 162) (in query: SELECT addYears();) 2025.06.13 15:42:31.173810 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addYears doesn't match: passed 0, should be 2 or 3: In scope SELECT addYears(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:31.211278 [ 6234 ] {c01c61a5-e1a2-4ca2-b01f-5efff8d19083} 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.20286.altinityantalya (altinity build)) (from [::1]:56348) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 10, line 15) (in query: SELECT count() FROM merge_tree WHERE not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003218d1b0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0c69 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:42:31.228906 [ 6234 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003218d1b0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0c69 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:42:31.253514 [ 8430 ] {357a6c8a-1e6e-4768-bf1b-4200d9770a0a} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test_table_compound_alia.value.value_` in scope SELECT test_table_compound_alia.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound_alias.value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56428) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT test_table_compound_alia.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:31.255862 [ 8431 ] {2b72e95c-42ea-4609-b9ea-751857f073b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 0, should be 1: In scope SELECT addressToLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 162, line 163) (in query: SELECT addressToLine();) 2025.06.13 15:42:31.296511 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 0, should be 1: In scope SELECT addressToLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:31.298862 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `test_table_compound_alia.value.value_` in scope SELECT test_table_compound_alia.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound_alias.value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:31.458032 [ 8431 ] {a6fe661b-e608-4d4f-bcb2-66f2e249e559} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 0, should be 1: In scope SELECT addressToLineWithInlines(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 163, line 164) (in query: SELECT addressToLineWithInlines();) 2025.06.13 15:42:31.485585 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 0, should be 1: In scope SELECT addressToLineWithInlines(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:31.625205 [ 8431 ] {497cb579-e66c-4125-97a0-cdf60a952fa9} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 0, should be 1: In scope SELECT addressToSymbol(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 164, line 165) (in query: SELECT addressToSymbol();) 2025.06.13 15:42:31.646231 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 0, should be 1: In scope SELECT addressToSymbol(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:31.791433 [ 8431 ] {22086b12-87f4-40a1-a37c-fd4cb6707942} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_decrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 165, line 166) (in query: SELECT aes_decrypt_mysql();) 2025.06.13 15:42:31.799548 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_decrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:31.877029 [ 8101 ] {a16feb26-069c-49a2-a126-7b713203aa81} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `value.value_` in scope SELECT value.value_ FROM (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SETTINGS enable_analyzer = 1. Maybe you meant: ['value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56432) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT value.value_ FROM (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:31.893472 [ 8431 ] {2d1ac8e7-134c-447c-80c9-2272a877a23d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_encrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 166, line 167) (in query: SELECT aes_encrypt_mysql();) 2025.06.13 15:42:31.904000 [ 8101 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `value.value_` in scope SELECT value.value_ FROM (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SETTINGS enable_analyzer = 1. Maybe you meant: ['value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:31.909202 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_encrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:32.007040 [ 8431 ] {c487fee7-6d87-4d7a-b676-47b61b2261fb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'age'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT age(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 167, line 168) (in query: SELECT age();) 2025.06.13 15:42:32.027615 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'age'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT age(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:32.167729 [ 8431 ] {2efa37aa-c17b-4b23-96f5-0c4075d0d90f} executeQuery: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 168, line 169) (in query: SELECT aggThrow();) 2025.06.13 15:42:32.204771 [ 8431 ] {} TCPHandler: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) 2025.06.13 15:42:32.380858 [ 8431 ] {a6e5a3eb-38b4-486f-920d-03375d8aefb8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT alphaTokens(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 169, line 170) (in query: SELECT alphaTokens();) 2025.06.13 15:42:32.425810 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT alphaTokens(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:32.447744 [ 7755 ] {2e2d296c-5601-4135-b0c9-7ca2d39765bc} executeQuery: Code: 47. DB::Exception: Identifier subquery.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from subquery with name subquery. In scope SELECT subquery.value.value_ FROM (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56444) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT subquery.value.value_ FROM (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) AS subquery SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x000000002d1467f7 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:257: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000002d13617b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:526: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d1394e1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:32.480679 [ 7755 ] {} TCPHandler: Code: 47. DB::Exception: Identifier subquery.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from subquery with name subquery. In scope SELECT subquery.value.value_ FROM (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x000000002d1467f7 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:257: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000002d13617b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:526: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d1394e1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:32.562317 [ 8431 ] {2346165d-55c5-46c6-838b-505e6b620910} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 170, line 171) (in query: SELECT analysisOfVariance();) 2025.06.13 15:42:32.568386 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:32.703024 [ 8431 ] {d7107cb5-33d3-47f4-b46c-05f4b9ddd5ec} executeQuery: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 0: In scope SELECT and(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 171, line 172) (in query: SELECT and();) 2025.06.13 15:42:32.724633 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 0: In scope SELECT and(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:32.888114 [ 8431 ] {e6f9a869-9db6-480c-b02d-849355dbf0e3} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 172, line 173) (in query: SELECT anova();) 2025.06.13 15:42:32.926242 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:33.029034 [ 8431 ] {79e125e6-5fb4-4c4c-bbb4-82c9ccd3592b} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 173, line 174) (in query: SELECT any();) 2025.06.13 15:42:33.052904 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:33.089203 [ 8430 ] {fac14b88-0401-4a03-8c31-f0369ea8fbf9} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `subquer.value.value_` in scope SELECT subquer.value.value_ FROM (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56462) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT subquer.value.value_ FROM (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) AS subquery SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:33.139895 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `subquer.value.value_` in scope SELECT subquer.value.value_ FROM (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:33.186850 [ 8431 ] {ce0c00f1-5f44-41a8-a8f6-7dd45335dab4} executeQuery: Code: 42. DB::Exception: Aggregate function anyHeavy requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 174, line 175) (in query: SELECT anyHeavy();) 2025.06.13 15:42:33.211532 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyHeavy requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:33.411434 [ 8431 ] {9ad1b79c-e217-4f34-8a8d-c8896c3d4424} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 175, line 176) (in query: SELECT anyLast();) 2025.06.13 15:42:33.423013 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:33.496119 [ 8431 ] {b464fb65-2ab8-4ddf-8c0d-13663eb67f7b} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 176, line 177) (in query: SELECT anyLastRespectNulls();) 2025.06.13 15:42:33.510768 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:33.610106 [ 8431 ] {a480f8fb-82bf-4ec5-932a-0229d94ba2af} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 177, line 178) (in query: SELECT anyLast_respect_nulls();) 2025.06.13 15:42:33.648179 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:33.715213 [ 5978 ] {4573ddd9-c516-46a7-9451-95e75ab57a0d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `value.value_` in scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55752) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: WITH cte_subquery AS (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) SELECT value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:33.764659 [ 5978 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `value.value_` in scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:33.800437 [ 8431 ] {06aacb53-e783-4899-8d9c-a5659a9e69c6} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 178, line 179) (in query: SELECT anyRespectNulls();) 2025.06.13 15:42:33.827465 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:33.991944 [ 8431 ] {4b3f1ee0-fc60-49b4-a61c-3964e77ac0fc} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 179, line 180) (in query: SELECT anyValueRespectNulls();) 2025.06.13 15:42:34.028277 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:34.162478 [ 8431 ] {01b70913-94f8-4707-9c15-7067246cc741} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 180, line 181) (in query: SELECT any_respect_nulls();) 2025.06.13 15:42:34.198496 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:34.221653 [ 8442 ] {f272c84d-4af9-43c9-a9c5-75ae74147106} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 940, line 941) (in query: SELECT nonNegativeDerivative(NULL, NULL);) 2025.06.13 15:42:34.235383 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.13 15:42:34.269309 [ 5978 ] {99513ec2-f629-4662-bec9-119436af3260} executeQuery: Code: 47. DB::Exception: Identifier cte_subquery.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from subquery. In scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery.value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55760) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: WITH cte_subquery AS (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery.value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x000000002d1467f7 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:257: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000002d13617b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:526: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d1394e1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:34.269467 [ 8431 ] {137f4497-28f7-4aea-855d-a7c3b1d6128b} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 181, line 182) (in query: SELECT any_value();) 2025.06.13 15:42:34.278943 [ 5978 ] {} TCPHandler: Code: 47. DB::Exception: Identifier cte_subquery.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from subquery. In scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery.value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x000000002d1467f7 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:257: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000002d13617b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:526: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d1394e1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:34.296806 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:34.466189 [ 8442 ] {71241bf2-8994-44ef-9e71-86f2e9985c2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT normL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 941, line 942) (in query: SELECT normL1(NULL, NULL);) 2025.06.13 15:42:34.477802 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT normL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:34.478041 [ 8431 ] {c3da3a25-26ea-4cc9-b25d-7078a503c3b7} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 182, line 183) (in query: SELECT any_value_respect_nulls();) 2025.06.13 15:42:34.484292 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:34.589665 [ 8431 ] {832929f2-bfde-4f90-a32f-e06527580f2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 0, should be 2: In scope SELECT appendTrailingCharIfAbsent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 183, line 184) (in query: SELECT appendTrailingCharIfAbsent();) 2025.06.13 15:42:34.596401 [ 8442 ] {8920ae5c-a4c2-465d-aff2-48861456a14e} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT normL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 942, line 943) (in query: SELECT normL2(NULL, NULL);) 2025.06.13 15:42:34.604229 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT normL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:34.610901 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 0, should be 2: In scope SELECT appendTrailingCharIfAbsent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:34.692190 [ 8442 ] {f27aea89-801f-4695-9a26-2b074ac413e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT normL2Squared(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 943, line 944) (in query: SELECT normL2Squared(NULL, NULL);) 2025.06.13 15:42:34.729768 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT normL2Squared(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:34.787277 [ 8431 ] {44cd9700-c7eb-4b0d-af98-fd34c33994be} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 184, line 185) (in query: SELECT approx_top_count();) 2025.06.13 15:42:34.806077 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:34.827820 [ 7755 ] {13936681-9383-4545-9f6d-d742a283121a} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `cte_subquer.value.value_` in scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquer.value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55796) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: WITH cte_subquery AS (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquer.value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:34.857121 [ 7755 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `cte_subquer.value.value_` in scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquer.value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:34.926645 [ 8442 ] {ff7dbadf-648f-4d8b-a7a0-0bc55c4fe490} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT normLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 944, line 945) (in query: SELECT normLinf(NULL, NULL);) 2025.06.13 15:42:34.954931 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT normLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:35.044219 [ 8431 ] {ed9d2a88-da3f-48d8-9b0f-e6d2915656f5} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 185, line 186) (in query: SELECT approx_top_k();) 2025.06.13 15:42:35.076099 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:35.221258 [ 8431 ] {8d9ee097-1a04-4c96-9163-e79355c654e4} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 186, line 187) (in query: SELECT approx_top_sum();) 2025.06.13 15:42:35.245235 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:35.343590 [ 8431 ] {7a960b26-dee9-4c8e-8403-6f54a6b79383} executeQuery: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 187, line 188) (in query: SELECT argMax();) 2025.06.13 15:42:35.377873 [ 8442 ] {54672ebb-3893-4b78-a392-e272d459e9e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 946, line 947) (in query: SELECT normalizeL1(NULL, NULL);) 2025.06.13 15:42:35.386243 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:35.386833 [ 18602 ] {d58c8b25-ecf2-45f1-a340-b19398d05613} executeQuery: Code: 47. DB::Exception: Identifier cte_subquery_alias.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from subquery with name cte_subquery_alias. In scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery_alias.value.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55814) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: WITH cte_subquery AS (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery_alias.value.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x000000002d1467f7 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:257: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000002d13617b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:526: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d1394e1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:35.399650 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:35.432251 [ 18602 ] {} TCPHandler: Code: 47. DB::Exception: Identifier cte_subquery_alias.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from subquery with name cte_subquery_alias. In scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery_alias.value.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x000000002d1467f7 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:257: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000002d13617b 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:526: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d1394e1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:35.517874 [ 8431 ] {7be8cab2-19c2-4cea-b7d6-8b08b4ef16e4} executeQuery: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 188, line 189) (in query: SELECT argMin();) 2025.06.13 15:42:35.524087 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:35.641265 [ 8442 ] {f46b66d9-4964-42ac-bf18-91a8623c936e} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 947, line 948) (in query: SELECT normalizeL2(NULL, NULL);) 2025.06.13 15:42:35.660290 [ 5978 ] {1923d5ff-e8cf-4b5e-a02a-881e0897b15a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function BLAKE3: In scope SELECT BLAKE3(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 4, line 4) (in query: SELECT BLAKE3(-1);) 2025.06.13 15:42:35.665523 [ 8432 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:42:35.667526 [ 8432 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:42:35.672219 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:35.678553 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function BLAKE3: In scope SELECT BLAKE3(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:35.786032 [ 8442 ] {2a0bf2e6-128b-4e7a-a0f3-e6b06cfd85d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT normalizeLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 948, line 949) (in query: SELECT normalizeLinf(NULL, NULL);) 2025.06.13 15:42:35.803269 [ 8430 ] {9a6b562e-0223-49a8-8c53-74b3e5671e45} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55740) (comment: 00211_shard_query_formatting_aliases.sql) (query 1, line 3) (in query: SELECT toUInt64(1) IN (1234567890, 2345678901, 3456789012, 4567890123, 5678901234, 6789012345, 7890123456, 8901234567, 9012345678, 123456789) AS x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x, x FROM remote('127.0.0.2', system, one) SETTINGS max_query_size = 10000;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:42:35.829016 [ 5978 ] {063f6cf1-cb65-4b18-8c98-2501c21911bb} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function lengthUTF8: In scope SELECT CHARACTER_LENGTH(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 5, line 6) (in query: SELECT CHARACTER_LENGTH(-1);) 2025.06.13 15:42:35.831960 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT normalizeLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:35.837141 [ 8430 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:42:35.850670 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function lengthUTF8: In scope SELECT CHARACTER_LENGTH(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:35.921236 [ 8431 ] {b7b27141-8b3b-49b7-9b3a-a24fc469e0f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 0, should be 2, 3 or 4: In scope SELECT arrayAUC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 190, line 191) (in query: SELECT arrayAUC();) 2025.06.13 15:42:35.961410 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 0, should be 2, 3 or 4: In scope SELECT arrayAUC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:36.029588 [ 7755 ] {10d68704-64db-4cfa-838b-2f7ab64057fc} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `cte_subquery_alia.value.value_` in scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery_alia.value.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55832) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: WITH cte_subquery AS (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery_alia.value.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:36.056054 [ 5978 ] {80fcf7ba-bb96-4372-847a-aeb667211191} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function lengthUTF8: In scope SELECT CHAR_LENGTH(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 6, line 7) (in query: SELECT CHAR_LENGTH(-1);) 2025.06.13 15:42:36.066009 [ 7755 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `cte_subquery_alia.value.value_` in scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery_alia.value.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:36.070667 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function lengthUTF8: In scope SELECT CHAR_LENGTH(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:36.138771 [ 8431 ] {e841479b-4c81-46fe-8fe4-9dc281d08f8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 0, should be 2 or 3: In scope SELECT arrayAUCPR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 191, line 192) (in query: SELECT arrayAUCPR();) 2025.06.13 15:42:36.160855 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 0, should be 2 or 3: In scope SELECT arrayAUCPR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:36.172842 [ 8442 ] {d29ab362-fa98-4c52-98ad-190c50f3e1db} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 2, should be 1: In scope SELECT normalizeQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 950, line 951) (in query: SELECT normalizeQuery(NULL, NULL);) 2025.06.13 15:42:36.187403 [ 5978 ] {54102ef2-adfa-4b53-bfe7-11146c47cfcb} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 7, line 8) (in query: SELECT COVAR_POP(-1);) 2025.06.13 15:42:36.194579 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 2, should be 1: In scope SELECT normalizeQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:36.208508 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:36.296352 [ 8431 ] {21e17aa7-809b-435f-ab15-16671d9826df} executeQuery: Code: 42. DB::Exception: Function arrayAll needs at least 1 argument, passed 0: In scope SELECT arrayAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 192, line 193) (in query: SELECT arrayAll();) 2025.06.13 15:42:36.305731 [ 8442 ] {ae8f11a3-e3cd-42ae-aa1a-7730837d1118} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 951, line 952) (in query: SELECT normalizeQueryKeepNames(NULL, NULL);) 2025.06.13 15:42:36.313200 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayAll needs at least 1 argument, passed 0: In scope SELECT arrayAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:36.336702 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:36.337685 [ 5978 ] {7e4f6981-c9aa-46ae-8af4-4f136395a392} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 8, line 9) (in query: SELECT COVAR_SAMP(-1);) 2025.06.13 15:42:36.383881 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:36.536696 [ 8442 ] {7365649f-0abe-4935-b990-b03f6f89a1f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 952, line 953) (in query: SELECT normalizeUTF8NFC(NULL, NULL);) 2025.06.13 15:42:36.537234 [ 8431 ] {5992606a-b47b-4425-ab92-b11dd27524b0} executeQuery: Code: 42. DB::Exception: Function arrayAvg needs at least 1 argument, passed 0: In scope SELECT arrayAvg(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 193, line 194) (in query: SELECT arrayAvg();) 2025.06.13 15:42:36.537416 [ 5978 ] {ac2af59c-5e11-45b4-976a-37405d345af3} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function CRC32: In scope SELECT CRC32(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 9, line 10) (in query: SELECT CRC32(-1);) 2025.06.13 15:42:36.552518 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayAvg needs at least 1 argument, passed 0: In scope SELECT arrayAvg(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:36.552643 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:36.564549 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function CRC32: In scope SELECT CRC32(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:36.633595 [ 8430 ] {80166bf9-5c8c-4b3b-94f7-5082562cac42} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `constant_value.value_` in scope SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS constant_value, constant_value.value_ SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55866) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT cast(tuple(1), 'Tuple(value_1 String)') AS constant_value, constant_value.value_ SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:36.652236 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `constant_value.value_` in scope SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS constant_value, constant_value.value_ SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:36.682094 [ 8442 ] {7ebcded4-387d-4b83-83ef-ae83dbeb46c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 953, line 954) (in query: SELECT normalizeUTF8NFD(NULL, NULL);) 2025.06.13 15:42:36.691498 [ 5978 ] {617ce631-82b4-4285-87de-71ce39c5bb59} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function CRC32IEEE: In scope SELECT CRC32IEEE(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 10, line 11) (in query: SELECT CRC32IEEE(-1);) 2025.06.13 15:42:36.720388 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:36.721484 [ 8431 ] {609b5696-0877-4013-873c-552e4ceb7058} executeQuery: Code: 42. DB::Exception: Function arrayCompact needs at least 1 argument, passed 0: In scope SELECT arrayCompact(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 194, line 195) (in query: SELECT arrayCompact();) 2025.06.13 15:42:36.725762 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function CRC32IEEE: In scope SELECT CRC32IEEE(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:36.752102 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayCompact needs at least 1 argument, passed 0: In scope SELECT arrayCompact(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.029676 [ 8442 ] {1336c915-d23d-4524-81f1-c0a5d1918ac0} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 954, line 955) (in query: SELECT normalizeUTF8NFKC(NULL, NULL);) 2025.06.13 15:42:37.034257 [ 8431 ] {dc121d15-56ae-45d3-ab9d-ef5bd02ae7f1} executeQuery: Code: 42. DB::Exception: Function arrayConcat requires at least one argument.: In scope SELECT arrayConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 195, line 196) (in query: SELECT arrayConcat();) 2025.06.13 15:42:37.034897 [ 5978 ] {63c35b60-64a8-4017-be34-da51cff6afd2} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function CRC64: In scope SELECT CRC64(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 11, line 12) (in query: SELECT CRC64(-1);) 2025.06.13 15:42:37.037672 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.042635 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function CRC64: In scope SELECT CRC64(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:37.044699 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayConcat requires at least one argument.: In scope SELECT arrayConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.129281 [ 8442 ] {a8f5f69b-a9c5-40a5-9b8a-a743ec6ae00d} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 955, line 956) (in query: SELECT normalizeUTF8NFKD(NULL, NULL);) 2025.06.13 15:42:37.161344 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.212751 [ 5978 ] {230b5612-5146-462a-ba2e-1b470e4f1bc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT DATABASE(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 12, line 13) (in query: SELECT DATABASE(-1);) 2025.06.13 15:42:37.248486 [ 8431 ] {3f807e85-8f0b-490e-a867-e196a743d20a} executeQuery: Code: 42. DB::Exception: Function arrayCount needs at least 1 argument, passed 0: In scope SELECT arrayCount(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 196, line 197) (in query: SELECT arrayCount();) 2025.06.13 15:42:37.275469 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT DATABASE(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.280698 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayCount needs at least 1 argument, passed 0: In scope SELECT arrayCount(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.320239 [ 8430 ] {9c2ce63f-ae10-47d7-9f60-0c8645bddfab} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `constant_valu.value_` in scope SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS constant_value, constant_valu.value_ SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55890) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT cast(tuple(1), 'Tuple(value_1 String)') AS constant_value, constant_valu.value_ SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:37.352091 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `constant_valu.value_` in scope SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS constant_value, constant_valu.value_ SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:37.377582 [ 8442 ] {bb0da0e7-8d4c-4a42-8b3a-e662817bfbab} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 956, line 957) (in query: SELECT normalizedQueryHash(NULL, NULL);) 2025.06.13 15:42:37.383781 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.448398 [ 8431 ] {8677accc-28f4-4f0c-832f-848a9150810d} executeQuery: Code: 42. DB::Exception: Function arrayCumSum needs at least 1 argument, passed 0: In scope SELECT arrayCumSum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 197, line 198) (in query: SELECT arrayCumSum();) 2025.06.13 15:42:37.457501 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayCumSum needs at least 1 argument, passed 0: In scope SELECT arrayCumSum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.466134 [ 8442 ] {fe403234-7689-4671-982f-f25f70125af2} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 957, line 958) (in query: SELECT normalizedQueryHashKeepNames(NULL, NULL);) 2025.06.13 15:42:37.475441 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.560712 [ 8431 ] {c413f95f-cabc-4ea6-bc43-a9d037f4929b} executeQuery: Code: 42. DB::Exception: Function arrayCumSumNonNegative needs at least 1 argument, passed 0: In scope SELECT arrayCumSumNonNegative(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 198, line 199) (in query: SELECT arrayCumSumNonNegative();) 2025.06.13 15:42:37.573149 [ 8442 ] {47286729-e126-4d3e-81e7-1a971b2f5145} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 2, should be 1: In scope SELECT not(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 958, line 959) (in query: SELECT not(NULL, NULL);) 2025.06.13 15:42:37.584099 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayCumSumNonNegative needs at least 1 argument, passed 0: In scope SELECT arrayCumSumNonNegative(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.594046 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 2, should be 1: In scope SELECT not(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.599841 [ 5978 ] {6a131524-42b5-46b7-9a6a-8ace618f8daf} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 14, line 15) (in query: SELECT DATE_DIFF(-1);) 2025.06.13 15:42:37.617629 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.716154 [ 8442 ] {4b0aac6b-fd39-407d-a170-45f7f4fefe61} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 2, should be 1: In scope SELECT notEmpty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 959, line 960) (in query: SELECT notEmpty(NULL, NULL);) 2025.06.13 15:42:37.716434 [ 8431 ] {1d052ed2-06cd-4669-8289-b8f8b6fb0a13} executeQuery: Code: 42. DB::Exception: Function arrayDifference needs at least 1 argument, passed 0: In scope SELECT arrayDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 199, line 200) (in query: SELECT arrayDifference();) 2025.06.13 15:42:37.720687 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 2, should be 1: In scope SELECT notEmpty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.727455 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayDifference needs at least 1 argument, passed 0: In scope SELECT arrayDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.754091 [ 5978 ] {c12e5b37-b530-4f16-be13-d8e2c665c609} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 1, should be 2 or 3: In scope SELECT DATE_FORMAT(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 15, line 16) (in query: SELECT DATE_FORMAT(-1);) 2025.06.13 15:42:37.782053 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 1, should be 2 or 3: In scope SELECT DATE_FORMAT(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.877319 [ 8431 ] {b8efaf9b-c3a4-40ab-8327-b3eb646a7196} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 0, should be 1: In scope SELECT arrayDistinct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 200, line 201) (in query: SELECT arrayDistinct();) 2025.06.13 15:42:37.909712 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 0, should be 1: In scope SELECT arrayDistinct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.929207 [ 4107 ] {f77518f4-6bbf-44aa-859f-78534319ae5c} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `constant_value.value_` in scope lambda_argument -> (lambda_argument + constant_value.value_). Maybe you meant: ['constant_value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55900) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT cast(tuple(1), 'Tuple(value_1 String)') AS constant_value, arrayMap(lambda_argument -> lambda_argument + constant_value.value_, [1, 2, 3]) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc42299 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3434: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2e7c8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:37.952606 [ 5978 ] {38112627-7005-49c4-b5ab-a55a66db5100} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 1, should be 2 or 3: In scope SELECT DATE_TRUNC(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 16, line 17) (in query: SELECT DATE_TRUNC(-1);) 2025.06.13 15:42:37.983890 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 1, should be 2 or 3: In scope SELECT DATE_TRUNC(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:37.987940 [ 4107 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `constant_value.value_` in scope lambda_argument -> (lambda_argument + constant_value.value_). Maybe you meant: ['constant_value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc42299 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3434: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2e7c8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:42:38.074088 [ 8431 ] {e3958195-8f7b-4b9b-91a1-9919fe14997e} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 0, should be 2: In scope SELECT arrayDotProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 201, line 202) (in query: SELECT arrayDotProduct();) 2025.06.13 15:42:38.080385 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 0, should be 2: In scope SELECT arrayDotProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:38.131924 [ 5978 ] {6d204384-6f42-4370-83ba-7030e6ea73a2} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAY(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 17, line 18) (in query: SELECT DAY(-1);) 2025.06.13 15:42:38.158844 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAY(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:38.276041 [ 8431 ] {b85ba4aa-68a3-48ac-b02e-3b5ab0e89f14} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 0, should be 2: In scope SELECT arrayElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 202, line 203) (in query: SELECT arrayElement();) 2025.06.13 15:42:38.308850 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 0, should be 2: In scope SELECT arrayElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:38.314593 [ 5978 ] {85989fdf-b1bd-45af-9a03-d2ea0e6510dc} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFMONTH(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 18, line 19) (in query: SELECT DAYOFMONTH(-1);) 2025.06.13 15:42:38.320884 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFMONTH(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:38.513440 [ 5978 ] {9099d943-f09d-4736-9414-d2ac61fd48f9} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT DAYOFWEEK(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 19, line 20) (in query: SELECT DAYOFWEEK(-1);) 2025.06.13 15:42:38.525915 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT DAYOFWEEK(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:38.560438 [ 4107 ] {40f8a427-cd7f-4553-a7c0-0daaa12221ef} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `constant_value.value_` in scope (SELECT constant_value.value_). Maybe you meant: ['constant_value.value_1']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55936) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: WITH cast(tuple(1), 'Tuple(value_1 String)') AS constant_value SELECT (SELECT constant_value.value_) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:42:38.573596 [ 4107 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `constant_value.value_` in scope (SELECT constant_value.value_). Maybe you meant: ['constant_value.value_1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:42:38.584909 [ 8431 ] {24de3f06-d4b0-4941-933d-ed70dd18aa09} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 0, should be 2: In scope SELECT arrayElementOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 203, line 204) (in query: SELECT arrayElementOrNull();) 2025.06.13 15:42:38.613642 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 0, should be 2: In scope SELECT arrayElementOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:38.616429 [ 5978 ] {4facabf0-ef0b-4c19-a046-fa3e4ee304f3} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDayOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFYEAR(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 20, line 21) (in query: SELECT DAYOFYEAR(-1);) 2025.06.13 15:42:38.701873 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDayOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFYEAR(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:38.766533 [ 8431 ] {3db57924-31ee-4beb-8dbb-033ed0232436} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 0, should be 1: In scope SELECT arrayEnumerate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 204, line 205) (in query: SELECT arrayEnumerate();) 2025.06.13 15:42:38.835671 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 0, should be 1: In scope SELECT arrayEnumerate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:38.909613 [ 8431 ] {6960e168-a85f-4eeb-b589-be7ce58aa4e4} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateDense doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateDense(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 205, line 206) (in query: SELECT arrayEnumerateDense();) 2025.06.13 15:42:38.921837 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateDense doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateDense(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:38.991491 [ 4072 ] {65c9aa2f-1a98-4896-bad8-adcda5de1f6e} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_0gg4v3pj.async_inserts (dceff994-d79d-482b-a330-5855dfc7fc0e)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02015_async_inserts_5.sh) (in query: INSERT INTO test_0gg4v3pj.async_inserts (id, s) FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000030d6e4ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000030cf2baa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb2d2 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fea13 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:42:38.991842 [ 5978 ] {cc170fe0-f348-461a-b614-3bce0afe081f} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 1, should be 0: In scope SELECT FQDN(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 22, line 23) (in query: SELECT FQDN(-1);) 2025.06.13 15:42:38.995772 [ 4072 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_0gg4v3pj.async_inserts (id, s) FORMAT JSONEachRow': Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_0gg4v3pj.async_inserts (dceff994-d79d-482b-a330-5855dfc7fc0e)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000030d6e4ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000030cf2baa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb2d2 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fea13 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:38.999901 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 1, should be 0: In scope SELECT FQDN(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:39.001418 [ 18602 ] {2c7bd58f-35c2-4578-8300-3f2eca404df7} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_0gg4v3pj.async_inserts (dceff994-d79d-482b-a330-5855dfc7fc0e)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:38780) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000030d6e4ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000030cf2baa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb2d2 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fea13 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:42:39.003916 [ 8101 ] {6c57e414-d1ac-42dd-9d4e-94a0bca61e63} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_0gg4v3pj.async_inserts (dceff994-d79d-482b-a330-5855dfc7fc0e)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:38758) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000030d6e4ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000030cf2baa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb2d2 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fea13 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:42:39.004170 [ 8431 ] {ce9673c6-beb9-4230-9d5b-efa91c96ac6b} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateDenseRanked doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateDenseRanked(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 206, line 207) (in query: SELECT arrayEnumerateDenseRanked();) 2025.06.13 15:42:39.004821 [ 18602 ] {2c7bd58f-35c2-4578-8300-3f2eca404df7} DynamicQueryHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_0gg4v3pj.async_inserts (dceff994-d79d-482b-a330-5855dfc7fc0e)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000030d6e4ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000030cf2baa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb2d2 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fea13 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:39.005348 [ 8430 ] {cd0fc136-6eef-465d-b641-9ccdf3088a79} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_0gg4v3pj.async_inserts (dceff994-d79d-482b-a330-5855dfc7fc0e)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:38766) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000030d6e4ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000030cf2baa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb2d2 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fea13 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:42:39.006306 [ 8101 ] {6c57e414-d1ac-42dd-9d4e-94a0bca61e63} DynamicQueryHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_0gg4v3pj.async_inserts (dceff994-d79d-482b-a330-5855dfc7fc0e)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000030d6e4ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000030cf2baa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb2d2 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fea13 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:39.009349 [ 8430 ] {cd0fc136-6eef-465d-b641-9ccdf3088a79} DynamicQueryHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_0gg4v3pj.async_inserts (dceff994-d79d-482b-a330-5855dfc7fc0e)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000030d6e4ef 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4936: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000030cf2baa 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb2d2 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fea13 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:39.022671 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateDenseRanked doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateDenseRanked(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:39.127238 [ 5978 ] {9de97f71-b09c-4e35-b6cf-9b09350a6bd9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Decode'. Expected: String or FixedString, got: Int8: In scope SELECT FROM_BASE64(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 23, line 24) (in query: SELECT FROM_BASE64(-1);) 2025.06.13 15:42:39.133279 [ 8431 ] {f63e833c-066a-46eb-8a9c-3c1184eb87b5} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateUniq doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateUniq(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 207, line 208) (in query: SELECT arrayEnumerateUniq();) 2025.06.13 15:42:39.138378 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Decode'. Expected: String or FixedString, got: Int8: In scope SELECT FROM_BASE64(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:39.151875 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateUniq doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateUniq(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:39.239570 [ 5978 ] {b52514d9-6745-4062-95a6-30fc3df6d535} executeQuery: Code: 69. DB::Exception: Expected a non-negative integer, got: -1: In scope SELECT FROM_DAYS(-1). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 24, line 25) (in query: SELECT FROM_DAYS(-1);) 2025.06.13 15:42:39.259738 [ 5978 ] {} TCPHandler: Code: 69. DB::Exception: Expected a non-negative integer, got: -1: In scope SELECT FROM_DAYS(-1). (ARGUMENT_OUT_OF_BOUND) 2025.06.13 15:42:39.261620 [ 8431 ] {4858d28b-0c8f-4509-b645-b211d189d88d} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateUniqRanked doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateUniqRanked(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 208, line 209) (in query: SELECT arrayEnumerateUniqRanked();) 2025.06.13 15:42:39.277986 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateUniqRanked doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateUniqRanked(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:39.355879 [ 8431 ] {af107ae3-5871-4571-b4d9-7958dd600940} executeQuery: Code: 42. DB::Exception: Function arrayExists needs at least 1 argument, passed 0: In scope SELECT arrayExists(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 209, line 210) (in query: SELECT arrayExists();) 2025.06.13 15:42:39.368975 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayExists needs at least 1 argument, passed 0: In scope SELECT arrayExists(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:39.434758 [ 8431 ] {2d893feb-c923-4874-88dc-1fd7c98b99d7} executeQuery: Code: 42. DB::Exception: Function arrayFill needs at least 2 arguments, passed 0: In scope SELECT arrayFill(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 210, line 211) (in query: SELECT arrayFill();) 2025.06.13 15:42:39.453562 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFill needs at least 2 arguments, passed 0: In scope SELECT arrayFill(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:39.471550 [ 5978 ] {6e1efdd0-b652-456a-8e2c-fe8980259964} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT HOUR(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 26, line 27) (in query: SELECT HOUR(-1);) 2025.06.13 15:42:39.492483 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT HOUR(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:39.528830 [ 8431 ] {32466e15-8ae3-4afc-b128-3d8fd62f7d35} executeQuery: Code: 42. DB::Exception: Function arrayFilter needs at least 2 arguments, passed 0: In scope SELECT arrayFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 211, line 212) (in query: SELECT arrayFilter();) 2025.06.13 15:42:39.539917 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFilter needs at least 2 arguments, passed 0: In scope SELECT arrayFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:39.570820 [ 5978 ] {121a13fe-2d30-4968-81cf-5868a707bfde} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv6StringToNum: In scope SELECT INET6_ATON(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 27, line 28) (in query: SELECT INET6_ATON(-1);) 2025.06.13 15:42:39.575860 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv6StringToNum: In scope SELECT INET6_ATON(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:39.589802 [ 8431 ] {56e88787-0848-40d8-bbc7-cba61bfe1b75} executeQuery: Code: 42. DB::Exception: Function arrayFirst needs at least 2 arguments, passed 0: In scope SELECT arrayFirst(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 212, line 213) (in query: SELECT arrayFirst();) 2025.06.13 15:42:39.595082 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFirst needs at least 2 arguments, passed 0: In scope SELECT arrayFirst(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:39.627573 [ 5978 ] {e30542d8-f24e-43f2-be39-8a2f1a7bb15f} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv6NumToString, expected IPv6 or FixedString(16): In scope SELECT INET6_NTOA(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 28, line 29) (in query: SELECT INET6_NTOA(-1);) 2025.06.13 15:42:39.629407 [ 8431 ] {7e2c5334-d66b-4036-96a0-a7fdfc99f87f} executeQuery: Code: 42. DB::Exception: Function arrayFirstIndex needs at least 2 arguments, passed 0: In scope SELECT arrayFirstIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 213, line 214) (in query: SELECT arrayFirstIndex();) 2025.06.13 15:42:39.634059 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv6NumToString, expected IPv6 or FixedString(16): In scope SELECT INET6_NTOA(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:39.635372 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFirstIndex needs at least 2 arguments, passed 0: In scope SELECT arrayFirstIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:39.666944 [ 8442 ] {bf3e6e14-5276-440c-adde-b81d0dfcfcfc} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 970, line 971) (in query: SELECT now(NULL, NULL);) 2025.06.13 15:42:39.670774 [ 5978 ] {b044d83e-1a24-4aa0-b8df-42a6459c7f86} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv4StringToNum: In scope SELECT INET_ATON(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 29, line 30) (in query: SELECT INET_ATON(-1);) 2025.06.13 15:42:39.672361 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:39.676819 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv4StringToNum: In scope SELECT INET_ATON(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:39.685299 [ 5110 ] {d9949813-e852-4e93-a00f-e7a499642080} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 73740.79852 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56828) (comment: 03227_distinct_dynamic_types_json_paths.sql) (query 8, line 11) (in query: insert into test_json_dynamic_aggregate_functions select toJSONString(map('a' || number % 13, multiIf(number % 5 == 0, NULL, number % 5 == 1, number::UInt32, number % 5 == 2, 'str_' || number, number % 5 == 3, range(number % 5), toBool(number % 2)))) from numbers(100000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:42:39.710553 [ 8431 ] {41af2183-6300-4e17-bf7d-5b86db4091fe} executeQuery: Code: 42. DB::Exception: Function arrayFirstOrNull needs at least 2 arguments, passed 0: In scope SELECT arrayFirstOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 214, line 215) (in query: SELECT arrayFirstOrNull();) 2025.06.13 15:42:39.713521 [ 5978 ] {efb38978-9d4f-4cf2-a209-5a580f8a4d5a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function IPv4NumToString, expected IPv4 or UInt8 or UInt16 or UInt32: In scope SELECT INET_NTOA(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 30, line 31) (in query: SELECT INET_NTOA(-1);) 2025.06.13 15:42:39.716603 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFirstOrNull needs at least 2 arguments, passed 0: In scope SELECT arrayFirstOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:39.720969 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function IPv4NumToString, expected IPv4 or UInt8 or UInt16 or UInt32: In scope SELECT INET_NTOA(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:39.730716 [ 5110 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 73740.79852 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:42:39.846170 [ 8431 ] {374bb159-2bc0-48a0-ba76-d5e09effb355} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 0, should be 1: In scope SELECT arrayFlatten(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 215, line 216) (in query: SELECT arrayFlatten();) 2025.06.13 15:42:39.850269 [ 5978 ] {a9ade457-a068-47a2-abbb-70a18de81c47} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 1, should be 2: In scope SELECT IPv4CIDRToRange(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 31, line 32) (in query: SELECT IPv4CIDRToRange(-1);) 2025.06.13 15:42:39.866460 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 0, should be 1: In scope SELECT arrayFlatten(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:39.889456 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 1, should be 2: In scope SELECT IPv4CIDRToRange(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:40.000058 [ 8442 ] {cd0e84a1-f75b-4d86-8888-344ca55bc103} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 973, line 974) (in query: SELECT nth_value(NULL, NULL);) 2025.06.13 15:42:40.002303 [ 8431 ] {0e5f8933-4a0d-41cc-9b18-1f991b14cf40} executeQuery: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 216, line 217) (in query: SELECT arrayFold();) 2025.06.13 15:42:40.014088 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.13 15:42:40.018816 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:40.068502 [ 5978 ] {b0b52b60-3e44-4299-b3d7-30f115bb1c3d} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function IPv4NumToString, expected IPv4 or UInt8 or UInt16 or UInt32: In scope SELECT IPv4NumToString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 32, line 33) (in query: SELECT IPv4NumToString(-1);) 2025.06.13 15:42:40.075402 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function IPv4NumToString, expected IPv4 or UInt8 or UInt16 or UInt32: In scope SELECT IPv4NumToString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:40.104237 [ 8442 ] {dca10f4c-5fdb-423c-87c4-b6a9eff26375} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 974, line 975) (in query: SELECT ntile(NULL, NULL);) 2025.06.13 15:42:40.111296 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:40.112530 [ 5978 ] {3996ff21-3113-4e76-b2af-2bc72ca099a7} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function IPv4NumToStringClassC, expected IPv4 or UInt8 or UInt16 or UInt32: In scope SELECT IPv4NumToStringClassC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 33, line 34) (in query: SELECT IPv4NumToStringClassC(-1);) 2025.06.13 15:42:40.113183 [ 8431 ] {625d58bc-0857-493c-8c5b-610500c33484} executeQuery: Code: 42. DB::Exception: Function arrayIntersect requires at least one argument.: In scope SELECT arrayIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 217, line 218) (in query: SELECT arrayIntersect();) 2025.06.13 15:42:40.116930 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function IPv4NumToStringClassC, expected IPv4 or UInt8 or UInt16 or UInt32: In scope SELECT IPv4NumToStringClassC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:40.118410 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayIntersect requires at least one argument.: In scope SELECT arrayIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:40.323589 [ 8431 ] {14c4a997-4c63-4962-bc1e-94dd7959bc3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 0, should be 2: In scope SELECT arrayJaccardIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 218, line 219) (in query: SELECT arrayJaccardIndex();) 2025.06.13 15:42:40.326174 [ 5978 ] {3e7377d2-42b2-4938-8a51-d934e08544f4} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv4StringToNum: In scope SELECT IPv4StringToNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 34, line 35) (in query: SELECT IPv4StringToNum(-1);) 2025.06.13 15:42:40.330857 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 0, should be 2: In scope SELECT arrayJaccardIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:40.336102 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv4StringToNum: In scope SELECT IPv4StringToNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:40.373662 [ 8430 ] {19323a1a-ef44-47ac-9a80-f1cbe9652a46} executeQuery: Code: 47. DB::Exception: Identifier 'test_table_1.value_' cannot be resolved from table with name test_13.test_table_1. In scope SELECT test_table_1.value_ FROM test_table_1 INNER JOIN test_table_2 ON test_table_1.id = test_table_2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_1.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55974) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT test_table_1.value_ FROM test_table_1 INNER JOIN test_table_2 ON test_table_1.id = test_table_2.id SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:852: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13daf4 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13d018 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:40.394646 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Identifier 'test_table_1.value_' cannot be resolved from table with name test_13.test_table_1. In scope SELECT test_table_1.value_ FROM test_table_1 INNER JOIN test_table_2 ON test_table_1.id = test_table_2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_1.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:852: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13daf4 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13d018 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:40.457573 [ 5978 ] {5086c4e4-b353-43ac-af36-97d4feec0fec} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv4StringToNumOrDefault: In scope SELECT IPv4StringToNumOrDefault(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 35, line 36) (in query: SELECT IPv4StringToNumOrDefault(-1);) 2025.06.13 15:42:40.464516 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv4StringToNumOrDefault: In scope SELECT IPv4StringToNumOrDefault(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:40.516951 [ 8431 ] {b53072a4-25de-494a-a50a-3bf9036d0d5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 0, should be 1: In scope SELECT arrayJoin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 219, line 220) (in query: SELECT arrayJoin();) 2025.06.13 15:42:40.531885 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 0, should be 1: In scope SELECT arrayJoin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:40.534007 [ 5978 ] {d34d2b7b-01ff-4ca0-87c3-534fd9fa2136} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv4StringToNumOrNull: In scope SELECT IPv4StringToNumOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 36, line 37) (in query: SELECT IPv4StringToNumOrNull(-1);) 2025.06.13 15:42:40.542349 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv4StringToNumOrNull: In scope SELECT IPv4StringToNumOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:40.620485 [ 8431 ] {b37ea461-17f8-46e2-8d8c-4f8d1d7fc0db} executeQuery: Code: 42. DB::Exception: Function arrayLast needs at least 2 arguments, passed 0: In scope SELECT arrayLast(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 220, line 221) (in query: SELECT arrayLast();) 2025.06.13 15:42:40.631124 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayLast needs at least 2 arguments, passed 0: In scope SELECT arrayLast(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:40.645092 [ 5978 ] {e2cf3672-f7b6-4cda-bb00-96cada26c4cd} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv4ToIPv6: In scope SELECT IPv4ToIPv6(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 37, line 38) (in query: SELECT IPv4ToIPv6(-1);) 2025.06.13 15:42:40.729336 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv4ToIPv6: In scope SELECT IPv4ToIPv6(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:40.734682 [ 8431 ] {bba9bfa6-f257-4303-bfe1-71ba5edb742f} executeQuery: Code: 42. DB::Exception: Function arrayLastIndex needs at least 2 arguments, passed 0: In scope SELECT arrayLastIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 221, line 222) (in query: SELECT arrayLastIndex();) 2025.06.13 15:42:40.751408 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayLastIndex needs at least 2 arguments, passed 0: In scope SELECT arrayLastIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:40.798165 [ 5978 ] {433c9c86-d14e-46c8-a30a-4015b101ff45} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 1, should be 2: In scope SELECT IPv6CIDRToRange(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 38, line 39) (in query: SELECT IPv6CIDRToRange(-1);) 2025.06.13 15:42:40.803728 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 1, should be 2: In scope SELECT IPv6CIDRToRange(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:40.854755 [ 8431 ] {98f769d5-a690-447b-bc46-0efba14ab000} executeQuery: Code: 42. DB::Exception: Function arrayLastOrNull needs at least 2 arguments, passed 0: In scope SELECT arrayLastOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 222, line 223) (in query: SELECT arrayLastOrNull();) 2025.06.13 15:42:40.861506 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayLastOrNull needs at least 2 arguments, passed 0: In scope SELECT arrayLastOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:40.944611 [ 5978 ] {b1532d53-675c-4626-ab5c-536ed4d87806} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv6NumToString, expected IPv6 or FixedString(16): In scope SELECT IPv6NumToString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 39, line 40) (in query: SELECT IPv6NumToString(-1);) 2025.06.13 15:42:40.967374 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv6NumToString, expected IPv6 or FixedString(16): In scope SELECT IPv6NumToString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:41.107664 [ 8431 ] {11a012d9-3236-4a54-9c2d-3604fbe83999} executeQuery: Code: 42. DB::Exception: Function arrayMap needs at least 2 arguments, passed 0: In scope SELECT arrayMap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 223, line 224) (in query: SELECT arrayMap();) 2025.06.13 15:42:41.123386 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayMap needs at least 2 arguments, passed 0: In scope SELECT arrayMap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:41.131654 [ 5978 ] {0e7fda35-e750-4abf-9134-11f1b3a4f4a4} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv6StringToNum: In scope SELECT IPv6StringToNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 40, line 41) (in query: SELECT IPv6StringToNum(-1);) 2025.06.13 15:42:41.132892 [ 8430 ] {db16b30a-dc92-489d-b298-701d1ee65bcb} executeQuery: Code: 47. DB::Exception: Identifier 'test_table_2.value_' cannot be resolved from table with name test_13.test_table_2. In scope SELECT test_table_2.value_ FROM test_table_1 INNER JOIN test_table_2 ON test_table_1.id = test_table_2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_2.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55990) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT test_table_2.value_ FROM test_table_1 INNER JOIN test_table_2 ON test_table_1.id = test_table_2.id SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:853: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13db35 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13d018 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:41.143424 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv6StringToNum: In scope SELECT IPv6StringToNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:41.178394 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Identifier 'test_table_2.value_' cannot be resolved from table with name test_13.test_table_2. In scope SELECT test_table_2.value_ FROM test_table_1 INNER JOIN test_table_2 ON test_table_1.id = test_table_2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_2.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:853: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13db35 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13d018 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:41.244825 [ 8431 ] {24982858-a2b8-4f6a-a71c-e226b40d6590} executeQuery: Code: 42. DB::Exception: Function arrayMax needs at least 1 argument, passed 0: In scope SELECT arrayMax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 224, line 225) (in query: SELECT arrayMax();) 2025.06.13 15:42:41.261108 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayMax needs at least 1 argument, passed 0: In scope SELECT arrayMax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:41.357075 [ 5978 ] {0e1eefc3-cfbb-40ca-9861-bbaa85cdf48c} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv6StringToNumOrDefault: In scope SELECT IPv6StringToNumOrDefault(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 41, line 42) (in query: SELECT IPv6StringToNumOrDefault(-1);) 2025.06.13 15:42:41.366745 [ 8431 ] {fac29ef5-3da0-4c53-937e-10db70068114} executeQuery: Code: 42. DB::Exception: Function arrayMin needs at least 1 argument, passed 0: In scope SELECT arrayMin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 225, line 226) (in query: SELECT arrayMin();) 2025.06.13 15:42:41.378047 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv6StringToNumOrDefault: In scope SELECT IPv6StringToNumOrDefault(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:41.381968 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayMin needs at least 1 argument, passed 0: In scope SELECT arrayMin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:41.473315 [ 5978 ] {5de696f4-8f3a-42ef-8d94-b288df21ef34} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv6StringToNumOrNull: In scope SELECT IPv6StringToNumOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 42, line 43) (in query: SELECT IPv6StringToNumOrNull(-1);) 2025.06.13 15:42:41.477876 [ 8431 ] {0a2ca008-b88f-4ab2-8474-d98ae6967838} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 0, should be 2: In scope SELECT arrayNormalizedGini(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 226, line 227) (in query: SELECT arrayNormalizedGini();) 2025.06.13 15:42:41.480472 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function IPv6StringToNumOrNull: In scope SELECT IPv6StringToNumOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:41.485948 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 0, should be 2: In scope SELECT arrayNormalizedGini(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:41.553038 [ 5978 ] {cc376ea0-4437-4102-8d17-27070d5d35e0} executeQuery: Code: 42. DB::Exception: Function JSONAllPaths requires argument with type JSON, got: Int8: In scope SELECT JSONAllPaths(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 43, line 44) (in query: SELECT JSONAllPaths(-1);) 2025.06.13 15:42:41.566730 [ 8431 ] {4368330f-b9ca-4002-8d86-4de56b5558e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 0, should be 2 or 3: In scope SELECT arrayPRAUC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 227, line 228) (in query: SELECT arrayPRAUC();) 2025.06.13 15:42:41.568901 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONAllPaths requires argument with type JSON, got: Int8: In scope SELECT JSONAllPaths(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:41.576889 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 0, should be 2 or 3: In scope SELECT arrayPRAUC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:41.648873 [ 5978 ] {c61d2c30-9311-47a0-a49c-8c293b9d9bab} executeQuery: Code: 42. DB::Exception: Function JSONAllPathsWithTypes requires argument with type JSON, got: Int8: In scope SELECT JSONAllPathsWithTypes(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 44, line 45) (in query: SELECT JSONAllPathsWithTypes(-1);) 2025.06.13 15:42:41.650555 [ 8431 ] {df4e1de6-a791-4eb7-aeae-a287ff9a6002} executeQuery: Code: 42. DB::Exception: Function arrayPartialReverseSort needs at least 2 arguments, passed 0: In scope SELECT arrayPartialReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 228, line 229) (in query: SELECT arrayPartialReverseSort();) 2025.06.13 15:42:41.655458 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONAllPathsWithTypes requires argument with type JSON, got: Int8: In scope SELECT JSONAllPathsWithTypes(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:41.658239 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayPartialReverseSort needs at least 2 arguments, passed 0: In scope SELECT arrayPartialReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:41.675301 [ 8430 ] {d38c9dba-16ea-4eec-ad59-8c77d9d0f91e} executeQuery: Code: 47. DB::Exception: Identifier 't1.value_' cannot be resolved from table with name t1. In scope SELECT t1.value_ FROM test_table_1 AS t1 INNER JOIN test_table_2 AS t2 ON t1.id = t2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['t1.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56004) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT t1.value_ FROM test_table_1 AS t1 INNER JOIN test_table_2 AS t2 ON t1.id = t2.id SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:852: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13daf4 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13d018 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:41.695268 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Identifier 't1.value_' cannot be resolved from table with name t1. In scope SELECT t1.value_ FROM test_table_1 AS t1 INNER JOIN test_table_2 AS t2 ON t1.id = t2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['t1.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:852: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13daf4 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13d018 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:41.741314 [ 8431 ] {ef0e3eaa-a225-41ff-a0ea-6e2aae6db25c} executeQuery: Code: 42. DB::Exception: Function 'arrayPartialShuffle' needs from 1 to 3 arguments, passed 0.: In scope SELECT arrayPartialShuffle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 229, line 230) (in query: SELECT arrayPartialShuffle();) 2025.06.13 15:42:41.748517 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'arrayPartialShuffle' needs from 1 to 3 arguments, passed 0.: In scope SELECT arrayPartialShuffle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:41.756753 [ 5978 ] {3bbe0aca-cf6c-45db-a46a-5a5238796ff1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'json' to function 'JSONArrayLength'. Expected: String, got: Int8: In scope SELECT JSONArrayLength(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 45, line 46) (in query: SELECT JSONArrayLength(-1);) 2025.06.13 15:42:41.778384 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'json' to function 'JSONArrayLength'. Expected: String, got: Int8: In scope SELECT JSONArrayLength(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:41.962647 [ 8431 ] {5103ca54-bc3e-4389-b4fd-1d576d76c6e4} executeQuery: Code: 42. DB::Exception: Function arrayPartialSort needs at least 2 arguments, passed 0: In scope SELECT arrayPartialSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 230, line 231) (in query: SELECT arrayPartialSort();) 2025.06.13 15:42:41.975901 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayPartialSort needs at least 2 arguments, passed 0: In scope SELECT arrayPartialSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:41.988740 [ 5978 ] {ace89ea2-78c0-4ebe-a62e-c1d655be2d9a} executeQuery: Code: 42. DB::Exception: Function JSONDynamicPaths requires argument with type JSON, got: Int8: In scope SELECT JSONDynamicPaths(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 46, line 47) (in query: SELECT JSONDynamicPaths(-1);) 2025.06.13 15:42:42.013329 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONDynamicPaths requires argument with type JSON, got: Int8: In scope SELECT JSONDynamicPaths(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:42.056408 [ 8431 ] {70ecb520-aba6-4743-96bb-5c5eea5774f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 0, should be 1: In scope SELECT arrayPopBack(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 231, line 232) (in query: SELECT arrayPopBack();) 2025.06.13 15:42:42.061306 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 0, should be 1: In scope SELECT arrayPopBack(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:42.115124 [ 5978 ] {2c2eaffc-b5c6-413d-ac6b-c22aaf5b2134} executeQuery: Code: 42. DB::Exception: Function JSONDynamicPathsWithTypes requires argument with type JSON, got: Int8: In scope SELECT JSONDynamicPathsWithTypes(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 47, line 48) (in query: SELECT JSONDynamicPathsWithTypes(-1);) 2025.06.13 15:42:42.115671 [ 8431 ] {650eabbf-c545-48a4-9c6b-959cb9880f0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 0, should be 1: In scope SELECT arrayPopFront(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 232, line 233) (in query: SELECT arrayPopFront();) 2025.06.13 15:42:42.124272 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 0, should be 1: In scope SELECT arrayPopFront(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:42.134915 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONDynamicPathsWithTypes requires argument with type JSON, got: Int8: In scope SELECT JSONDynamicPathsWithTypes(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:42.163679 [ 8430 ] {a2a9d26d-185c-42c5-87aa-b803c2a7b451} executeQuery: Code: 47. DB::Exception: Identifier 't2.value_' cannot be resolved from table with name t2. In scope SELECT t2.value_ FROM test_table_1 AS t1 INNER JOIN test_table_2 AS t2 ON t1.id = t2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['t2.value']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56006) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT t2.value_ FROM test_table_1 AS t1 INNER JOIN test_table_2 AS t2 ON t1.id = t2.id SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:853: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13db35 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13d018 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:42.192594 [ 5978 ] {2c02e290-c9d2-4973-91bc-2008660c659e} executeQuery: Code: 42. DB::Exception: Function JSONExtract requires at least two arguments: In scope SELECT JSONExtract(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 48, line 49) (in query: SELECT JSONExtract(-1);) 2025.06.13 15:42:42.193578 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Identifier 't2.value_' cannot be resolved from table with name t2. In scope SELECT t2.value_ FROM test_table_1 AS t1 INNER JOIN test_table_2 AS t2 ON t1.id = t2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['t2.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002d146a8f 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:601: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002d13a5f0 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13ae0d 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1349: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13cfea 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:853: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13db35 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1329: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002d13d018 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002d1453db 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1db42 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:42:42.201683 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtract requires at least two arguments: In scope SELECT JSONExtract(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:42.211765 [ 8431 ] {4b506976-8544-4a86-861b-89eb2cb46103} executeQuery: Code: 42. DB::Exception: Function arrayProduct needs at least 1 argument, passed 0: In scope SELECT arrayProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 233, line 234) (in query: SELECT arrayProduct();) 2025.06.13 15:42:42.233555 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayProduct needs at least 1 argument, passed 0: In scope SELECT arrayProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:42.309869 [ 5978 ] {e110c2be-eb11-4edf-9899-1e47da9919cb} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractArrayRaw should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractArrayRaw(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 49, line 50) (in query: SELECT JSONExtractArrayRaw(-1);) 2025.06.13 15:42:42.324666 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractArrayRaw should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractArrayRaw(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:42.353664 [ 8431 ] {71408922-5c7e-4734-a02c-78cdbc147f41} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 0, should be 2: In scope SELECT arrayPushBack(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 234, line 235) (in query: SELECT arrayPushBack();) 2025.06.13 15:42:42.390217 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 0, should be 2: In scope SELECT arrayPushBack(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:42.459015 [ 5978 ] {161590f7-17cd-44a3-9f89-7962481a10e3} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractBool should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractBool(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 50, line 51) (in query: SELECT JSONExtractBool(-1);) 2025.06.13 15:42:42.473812 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractBool should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractBool(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:42.550292 [ 8431 ] {3e82054f-809f-4e96-a8aa-20c3d3181873} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 0, should be 2: In scope SELECT arrayPushFront(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 235, line 236) (in query: SELECT arrayPushFront();) 2025.06.13 15:42:42.572286 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 0, should be 2: In scope SELECT arrayPushFront(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:42.584570 [ 5978 ] {520a28e4-c038-484f-8f4c-db91b3ea939f} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractFloat should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractFloat(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 51, line 52) (in query: SELECT JSONExtractFloat(-1);) 2025.06.13 15:42:42.601917 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractFloat should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractFloat(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:42.661529 [ 8431 ] {6096d4ac-5623-47a6-93dd-d27a844c6922} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 0, should be 2, 3 or 4: In scope SELECT arrayROCAUC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 236, line 237) (in query: SELECT arrayROCAUC();) 2025.06.13 15:42:42.662439 [ 8430 ] {35aa3b8a-cecf-4079-a341-b809d1583fa8} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a.size1` in scope SELECT [1] AS a, a.size1 SETTINGS enable_analyzer = 1. Maybe you meant: ['a.size0']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56010) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT [1] AS a, a.size1 SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:42.669111 [ 5978 ] {80413de2-d040-4a05-87b5-19d504cac9ed} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractInt should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractInt(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 52, line 53) (in query: SELECT JSONExtractInt(-1);) 2025.06.13 15:42:42.669167 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 0, should be 2, 3 or 4: In scope SELECT arrayROCAUC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:42.690188 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `a.size1` in scope SELECT [1] AS a, a.size1 SETTINGS enable_analyzer = 1. Maybe you meant: ['a.size0']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:42.698004 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractInt should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractInt(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:42.819968 [ 8431 ] {98703ac8-a6ec-459c-90b5-79aafa910199} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 0, should be 2: In scope SELECT arrayRandomSample(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 237, line 238) (in query: SELECT arrayRandomSample();) 2025.06.13 15:42:42.838778 [ 5978 ] {f5d09aad-a5cc-47ca-903d-a8bbe132d7c5} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractKeys should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractKeys(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 53, line 54) (in query: SELECT JSONExtractKeys(-1);) 2025.06.13 15:42:42.838897 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 0, should be 2: In scope SELECT arrayRandomSample(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:42.884464 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractKeys should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractKeys(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:43.017386 [ 5978 ] {cadc0d77-56bf-4a2e-91f8-bdd647eb5cdc} executeQuery: Code: 42. DB::Exception: Function JSONExtractKeysAndValues requires at least two arguments: In scope SELECT JSONExtractKeysAndValues(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 54, line 55) (in query: SELECT JSONExtractKeysAndValues(-1);) 2025.06.13 15:42:43.027266 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONExtractKeysAndValues requires at least two arguments: In scope SELECT JSONExtractKeysAndValues(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:43.034349 [ 8431 ] {673f73de-998d-4da3-9117-53dfc706ed4b} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayReduce doesn't match: passed 0, should be at least 2.: In scope SELECT arrayReduce(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 238, line 239) (in query: SELECT arrayReduce();) 2025.06.13 15:42:43.042223 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayReduce doesn't match: passed 0, should be at least 2.: In scope SELECT arrayReduce(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:43.102277 [ 5978 ] {cbe4df07-3611-4836-a2e5-2df1d74bb578} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractKeysAndValuesRaw should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractKeysAndValuesRaw(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 55, line 56) (in query: SELECT JSONExtractKeysAndValuesRaw(-1);) 2025.06.13 15:42:43.108857 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractKeysAndValuesRaw should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractKeysAndValuesRaw(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:43.125486 [ 8431 ] {8259a533-36ac-4b3d-99da-92326c26fb9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReduceInRanges doesn't match: passed 0, should be at least 3.: In scope SELECT arrayReduceInRanges(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 239, line 240) (in query: SELECT arrayReduceInRanges();) 2025.06.13 15:42:43.130805 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReduceInRanges doesn't match: passed 0, should be at least 3.: In scope SELECT arrayReduceInRanges(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:43.164526 [ 8430 ] {ee4a1f2c-90dc-4d0e-a91d-e3453cccf26d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `t.c` in scope SELECT CAST('((1))', 'Tuple(a Tuple(b UInt32))') AS t, t.c SETTINGS enable_analyzer = 1. Maybe you meant: ['t.a']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38132) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT ((1))::Tuple(a Tuple(b UInt32)) AS t, t.c SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:43.189862 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `t.c` in scope SELECT CAST('((1))', 'Tuple(a Tuple(b UInt32))') AS t, t.c SETTINGS enable_analyzer = 1. Maybe you meant: ['t.a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:43.190401 [ 8431 ] {1d8cfb65-6dcb-4445-af75-dd6d6c0c0563} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayResize'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT arrayResize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 240, line 241) (in query: SELECT arrayResize();) 2025.06.13 15:42:43.199136 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayResize'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT arrayResize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:43.241543 [ 5978 ] {6fd7480e-21c2-41cb-a3f8-394c6cc38934} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractRaw should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractRaw(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 56, line 57) (in query: SELECT JSONExtractRaw(-1);) 2025.06.13 15:42:43.266122 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractRaw should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractRaw(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:43.312113 [ 8431 ] {4a348f68-d4b5-4979-9e8c-1f2f32077cae} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 0, should be 1: In scope SELECT arrayReverse(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 241, line 242) (in query: SELECT arrayReverse();) 2025.06.13 15:42:43.328632 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 0, should be 1: In scope SELECT arrayReverse(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:43.396301 [ 5978 ] {ac5406b1-beb9-4fa3-b445-e3a30875a4c0} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractString should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 57, line 58) (in query: SELECT JSONExtractString(-1);) 2025.06.13 15:42:43.415281 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractString should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:43.427929 [ 8431 ] {0c28ddd0-a51e-4638-a851-ffd28c041002} executeQuery: Code: 42. DB::Exception: Function arrayReverseFill needs at least 2 arguments, passed 0: In scope SELECT arrayReverseFill(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 242, line 243) (in query: SELECT arrayReverseFill();) 2025.06.13 15:42:43.439051 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayReverseFill needs at least 2 arguments, passed 0: In scope SELECT arrayReverseFill(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:43.549555 [ 5978 ] {f7d56264-b211-4ff4-9fb6-3dbb6136db99} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractUInt should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractUInt(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 58, line 59) (in query: SELECT JSONExtractUInt(-1);) 2025.06.13 15:42:43.557596 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractUInt should be a string containing JSON, illegal type: Int8: In scope SELECT JSONExtractUInt(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:43.559052 [ 8431 ] {79cc7e37-b350-427e-ba4b-837c27f0736d} executeQuery: Code: 42. DB::Exception: Function arrayReverseSort needs at least 1 argument, passed 0: In scope SELECT arrayReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 243, line 244) (in query: SELECT arrayReverseSort();) 2025.06.13 15:42:43.567217 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayReverseSort needs at least 1 argument, passed 0: In scope SELECT arrayReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:43.647713 [ 5978 ] {36687878-cf8a-4061-a065-a6eaa5187092} executeQuery: Code: 43. DB::Exception: The first argument of function JSONHas should be a string containing JSON, illegal type: Int8: In scope SELECT JSONHas(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 59, line 60) (in query: SELECT JSONHas(-1);) 2025.06.13 15:42:43.648114 [ 8431 ] {7837c4d3-70de-4e02-90ae-06fd0f8987cf} executeQuery: Code: 42. DB::Exception: Function arrayReverseSplit needs at least 2 arguments, passed 0: In scope SELECT arrayReverseSplit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 244, line 245) (in query: SELECT arrayReverseSplit();) 2025.06.13 15:42:43.653951 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONHas should be a string containing JSON, illegal type: Int8: In scope SELECT JSONHas(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:43.655464 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayReverseSplit needs at least 2 arguments, passed 0: In scope SELECT arrayReverseSplit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:43.658544 [ 8430 ] {f31bf1a6-d3a5-4aeb-8adb-42102ffe7b7d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `t.a.c` in scope SELECT CAST('((1))', 'Tuple(a Tuple(b UInt32))') AS t, t.a.c SETTINGS enable_analyzer = 1. Maybe you meant: ['t.a.b']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38136) (comment: 02476_analyzer_identifier_hints.sh) (query 1, line 1) (in query: SELECT ((1))::Tuple(a Tuple(b UInt32)) AS t, t.a.c SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:43.682647 [ 8430 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `t.a.c` in scope SELECT CAST('((1))', 'Tuple(a Tuple(b UInt32))') AS t, t.a.c SETTINGS enable_analyzer = 1. Maybe you meant: ['t.a.b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:42:43.787068 [ 5978 ] {7ce491eb-3954-4e35-9931-673d1128acc2} executeQuery: Code: 43. DB::Exception: The first argument of function JSONKey should be a string containing JSON, illegal type: Int8: In scope SELECT JSONKey(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 60, line 61) (in query: SELECT JSONKey(-1);) 2025.06.13 15:42:43.787147 [ 8431 ] {7b727168-d5b4-4658-9802-909d15093a4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 0, should be 2: In scope SELECT arrayRotateLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 245, line 246) (in query: SELECT arrayRotateLeft();) 2025.06.13 15:42:43.802588 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 0, should be 2: In scope SELECT arrayRotateLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:43.808515 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONKey should be a string containing JSON, illegal type: Int8: In scope SELECT JSONKey(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:43.899851 [ 8431 ] {d3de8a81-dd21-49d1-bb76-f5c6f8fc3725} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 0, should be 2: In scope SELECT arrayRotateRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 246, line 247) (in query: SELECT arrayRotateRight();) 2025.06.13 15:42:43.900971 [ 5978 ] {7a2bde50-051f-4848-8504-c262b70e8450} executeQuery: Code: 43. DB::Exception: The first argument of function JSONLength should be a string containing JSON, illegal type: Int8: In scope SELECT JSONLength(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 61, line 62) (in query: SELECT JSONLength(-1);) 2025.06.13 15:42:43.930575 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONLength should be a string containing JSON, illegal type: Int8: In scope SELECT JSONLength(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:43.933902 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 0, should be 2: In scope SELECT arrayRotateRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:44.002165 [ 8431 ] {1d390849-f9e2-4511-a2b6-9f779b6dae3c} executeQuery: Code: 42. DB::Exception: Function arrayShiftLeft requires at least two arguments.: In scope SELECT arrayShiftLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 247, line 248) (in query: SELECT arrayShiftLeft();) 2025.06.13 15:42:44.007865 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayShiftLeft requires at least two arguments.: In scope SELECT arrayShiftLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:44.035056 [ 5978 ] {1dde5fac-6e35-4bbc-b3b7-aac6698a51fb} executeQuery: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT JSONMergePatch(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 62, line 63) (in query: SELECT JSONMergePatch(-1);) 2025.06.13 15:42:44.047825 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT JSONMergePatch(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:44.049342 [ 8431 ] {376d8411-3685-4df3-adc2-d50a12bbe6d2} executeQuery: Code: 42. DB::Exception: Function arrayShiftRight requires at least two arguments.: In scope SELECT arrayShiftRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 248, line 249) (in query: SELECT arrayShiftRight();) 2025.06.13 15:42:44.055076 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayShiftRight requires at least two arguments.: In scope SELECT arrayShiftRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:44.097868 [ 5978 ] {b020f5a0-50d6-4b4e-b4b7-f4163c4b03d7} executeQuery: Code: 42. DB::Exception: Function JSONSharedDataPaths requires argument with type JSON, got: Int8: In scope SELECT JSONSharedDataPaths(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 63, line 64) (in query: SELECT JSONSharedDataPaths(-1);) 2025.06.13 15:42:44.099562 [ 8431 ] {020259fc-ea90-43de-b871-f8d4201bbca2} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 0, should be 2: In scope SELECT arrayShingles(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 249, line 250) (in query: SELECT arrayShingles();) 2025.06.13 15:42:44.104070 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONSharedDataPaths requires argument with type JSON, got: Int8: In scope SELECT JSONSharedDataPaths(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:44.124878 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 0, should be 2: In scope SELECT arrayShingles(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:44.264640 [ 5978 ] {fd557fc4-59ef-4864-82ca-dcb6714bc201} executeQuery: Code: 42. DB::Exception: Function JSONSharedDataPathsWithTypes requires argument with type JSON, got: Int8: In scope SELECT JSONSharedDataPathsWithTypes(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 64, line 65) (in query: SELECT JSONSharedDataPathsWithTypes(-1);) 2025.06.13 15:42:44.271622 [ 8431 ] {690bbc7f-6aa2-4d8d-9198-46cb291070fb} executeQuery: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 0.: In scope SELECT arrayShuffle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 250, line 251) (in query: SELECT arrayShuffle();) 2025.06.13 15:42:44.274769 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function JSONSharedDataPathsWithTypes requires argument with type JSON, got: Int8: In scope SELECT JSONSharedDataPathsWithTypes(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:44.289727 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 0.: In scope SELECT arrayShuffle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:44.452069 [ 8431 ] {d9960ae6-c873-4f2a-bc7e-0d7469f0de75} executeQuery: Code: 42. DB::Exception: Number of arguments for function arraySlice doesn't match: passed 0, should be 2 or 3: In scope SELECT arraySlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 251, line 252) (in query: SELECT arraySlice();) 2025.06.13 15:42:44.463112 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arraySlice doesn't match: passed 0, should be 2 or 3: In scope SELECT arraySlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:44.474115 [ 5978 ] {02b04992-7303-46fe-9050-42258e6d623b} executeQuery: Code: 43. DB::Exception: The first argument of function JSONType should be a string containing JSON, illegal type: Int8: In scope SELECT JSONType(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 65, line 66) (in query: SELECT JSONType(-1);) 2025.06.13 15:42:44.490467 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONType should be a string containing JSON, illegal type: Int8: In scope SELECT JSONType(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:44.578227 [ 8431 ] {5199ed87-9598-4020-a182-50c8e87a8b93} executeQuery: Code: 42. DB::Exception: Function arraySort needs at least 1 argument, passed 0: In scope SELECT arraySort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 252, line 253) (in query: SELECT arraySort();) 2025.06.13 15:42:44.592017 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arraySort needs at least 1 argument, passed 0: In scope SELECT arraySort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:44.670946 [ 5978 ] {d6d4aec2-f187-4777-9969-92dabde66bc1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'json' to function 'JSONArrayLength'. Expected: String, got: Int8: In scope SELECT JSON_ARRAY_LENGTH(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 66, line 67) (in query: SELECT JSON_ARRAY_LENGTH(-1);) 2025.06.13 15:42:44.673357 [ 8431 ] {4086a439-38cc-426e-8d59-0c2659f3bb86} executeQuery: Code: 42. DB::Exception: Function arraySplit needs at least 2 arguments, passed 0: In scope SELECT arraySplit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 253, line 254) (in query: SELECT arraySplit();) 2025.06.13 15:42:44.676118 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'json' to function 'JSONArrayLength'. Expected: String, got: Int8: In scope SELECT JSON_ARRAY_LENGTH(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:44.701606 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arraySplit needs at least 2 arguments, passed 0: In scope SELECT arraySplit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:44.763335 [ 8431 ] {37f21019-a5cd-432d-9881-fe540fca3971} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayStringConcat'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT arrayStringConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 254, line 255) (in query: SELECT arrayStringConcat();) 2025.06.13 15:42:44.782620 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayStringConcat'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT arrayStringConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:44.827685 [ 5978 ] {b4aa95df-e214-43e5-ae03-ece8d997e354} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_EXISTS(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 67, line 68) (in query: SELECT JSON_EXISTS(-1);) 2025.06.13 15:42:44.832147 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_EXISTS(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:44.946490 [ 5978 ] {e8f364fd-3e20-4edb-94b8-4589a5e9d3b4} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_QUERY(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 68, line 69) (in query: SELECT JSON_QUERY(-1);) 2025.06.13 15:42:44.952857 [ 8431 ] {1dcce9ed-d7b4-4698-885d-107ef340029d} executeQuery: Code: 42. DB::Exception: Function arraySum needs at least 1 argument, passed 0: In scope SELECT arraySum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 255, line 256) (in query: SELECT arraySum();) 2025.06.13 15:42:44.957548 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_QUERY(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:45.026424 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arraySum needs at least 1 argument, passed 0: In scope SELECT arraySum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:45.149252 [ 5978 ] {6cf9190a-0b4f-4e09-865f-52e7b8896a23} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_VALUE(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 69, line 70) (in query: SELECT JSON_VALUE(-1);) 2025.06.13 15:42:45.150091 [ 8431 ] {5b574ec5-8c88-4620-b5d1-48514e45298b} executeQuery: Code: 42. DB::Exception: Function arraySymmetricDifference requires at least one argument.: In scope SELECT arraySymmetricDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 256, line 257) (in query: SELECT arraySymmetricDifference();) 2025.06.13 15:42:45.190088 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_VALUE(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:45.191784 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arraySymmetricDifference requires at least one argument.: In scope SELECT arraySymmetricDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:45.257008 [ 8431 ] {066a25fd-8d78-4ad2-9aec-0b2e9482008b} executeQuery: Code: 42. DB::Exception: Function arrayUnion requires at least one argument.: In scope SELECT arrayUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 257, line 258) (in query: SELECT arrayUnion();) 2025.06.13 15:42:45.266004 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayUnion requires at least one argument.: In scope SELECT arrayUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:45.277689 [ 5978 ] {d812cd9d-a82c-404d-b000-72d9db257703} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 1, should be 2: In scope SELECT L1Distance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 70, line 71) (in query: SELECT L1Distance(-1);) 2025.06.13 15:42:45.285090 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 1, should be 2: In scope SELECT L1Distance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:45.364764 [ 5978 ] {5857b8c4-12eb-483a-b58a-a9749b50ad15} executeQuery: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got Int8: In scope SELECT L1Norm(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 71, line 72) (in query: SELECT L1Norm(-1);) 2025.06.13 15:42:45.373351 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got Int8: In scope SELECT L1Norm(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:45.428032 [ 8431 ] {c2d0777f-d919-44b8-a317-948d006c0e0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayUniq doesn't match: passed 0, should be at least 1.: In scope SELECT arrayUniq(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 258, line 259) (in query: SELECT arrayUniq();) 2025.06.13 15:42:45.451934 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayUniq doesn't match: passed 0, should be at least 1.: In scope SELECT arrayUniq(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:45.473551 [ 5978 ] {03b89e2d-daba-4537-adbd-bdd19e029126} executeQuery: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got Int8: In scope SELECT L1Normalize(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 72, line 73) (in query: SELECT L1Normalize(-1);) 2025.06.13 15:42:45.503132 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got Int8: In scope SELECT L1Normalize(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:45.591769 [ 8431 ] {e4fab84e-d2b6-4dd9-92bd-7f61a3a046a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 0, should be 2: In scope SELECT arrayWithConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 259, line 260) (in query: SELECT arrayWithConstant();) 2025.06.13 15:42:45.617555 [ 5978 ] {d4d338c6-93c7-4d35-b728-934fb0bb63eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 1, should be 2: In scope SELECT L2Distance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 73, line 74) (in query: SELECT L2Distance(-1);) 2025.06.13 15:42:45.617990 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 0, should be 2: In scope SELECT arrayWithConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:45.641406 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 1, should be 2: In scope SELECT L2Distance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:45.775994 [ 5978 ] {089f158c-f409-4438-b89d-1d06dac0eccf} executeQuery: Code: 43. DB::Exception: Argument 0 of function L2Norm should be tuple, got Int8: In scope SELECT L2Norm(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 74, line 75) (in query: SELECT L2Norm(-1);) 2025.06.13 15:42:45.800446 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L2Norm should be tuple, got Int8: In scope SELECT L2Norm(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:45.938182 [ 5978 ] {76624da3-7454-4418-871e-153f33ad162d} executeQuery: Code: 43. DB::Exception: Argument 0 of function L2Norm should be tuple, got Int8: In scope SELECT L2Normalize(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 75, line 76) (in query: SELECT L2Normalize(-1);) 2025.06.13 15:42:45.952914 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L2Norm should be tuple, got Int8: In scope SELECT L2Normalize(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:46.055938 [ 5978 ] {fc013498-1e24-4823-8a96-5f59c8d00a46} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 1, should be 2: In scope SELECT L2SquaredDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 76, line 77) (in query: SELECT L2SquaredDistance(-1);) 2025.06.13 15:42:46.081850 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 1, should be 2: In scope SELECT L2SquaredDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:46.138885 [ 7279 ] {e9f84ec9-906b-4b4b-b277-2e0539d7faf1} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39200) (comment: 01319_manual_write_to_replicas_long.sql) (query 4, line 8) (in query: CREATE TABLE r2 (`x` String) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/r', 'r2') ORDER BY x SETTINGS index_granularity = 3305, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.942304253578186, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 405834009, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 15244657, merge_max_block_size = 8626, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 119308, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 7922545013, index_granularity_bytes = 26406440, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 39, 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 = 30064, primary_key_compress_block_size = 97128, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1419: Coordination::ZooKeeper::create(String const&, String const&, bool, bool, std::vector> const&, std::function) @ 0x000000003281ebae 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1203: zkutil::ZooKeeper::asyncTryCreateNoThrow(String const&, String const&, int) @ 0x000000003275621e 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:864: DB::StorageReplicatedMergeTree::createNewZooKeeperNodesAttempt() const @ 0x000000003059bc63 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:845: DB::StorageReplicatedMergeTree::createNewZooKeeperNodes(DB::ZooKeeperRetriesInfo const&) const @ 0x0000000030591abd 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:626: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x000000003058c430 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x00000000311c3e69 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x00000000311c3bd4 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd8cd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:42:46.155559 [ 7279 ] {} TCPHandler: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1419: Coordination::ZooKeeper::create(String const&, String const&, bool, bool, std::vector> const&, std::function) @ 0x000000003281ebae 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1203: zkutil::ZooKeeper::asyncTryCreateNoThrow(String const&, String const&, int) @ 0x000000003275621e 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:864: DB::StorageReplicatedMergeTree::createNewZooKeeperNodesAttempt() const @ 0x000000003059bc63 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:845: DB::StorageReplicatedMergeTree::createNewZooKeeperNodes(DB::ZooKeeperRetriesInfo const&) const @ 0x0000000030591abd 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:626: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x000000003058c430 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x00000000311c3e69 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x00000000311c3bd4 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd8cd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:42:46.240909 [ 5978 ] {36edb0e7-edfe-4145-aa3c-fbf2a2dfc3d3} executeQuery: Code: 43. DB::Exception: Argument 0 of function L2SquaredNorm should be tuple, got Int8: In scope SELECT L2SquaredNorm(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 77, line 78) (in query: SELECT L2SquaredNorm(-1);) 2025.06.13 15:42:46.252121 [ 8431 ] {71d62527-9b0e-49fb-ba42-645ec2746262} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 262, line 263) (in query: SELECT array_agg();) 2025.06.13 15:42:46.257881 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:46.266871 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L2SquaredNorm should be tuple, got Int8: In scope SELECT L2SquaredNorm(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:46.350109 [ 8431 ] {7ab65b77-119f-4b46-ba53-2ea259772e26} executeQuery: Code: 35. DB::Exception: Array aggregate functions require at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 263, line 264) (in query: SELECT array_concat_agg();) 2025.06.13 15:42:46.351098 [ 5978 ] {e7510547-9666-4958-bc46-f0d756e71117} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toLastDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT LAST_DAY(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 78, line 79) (in query: SELECT LAST_DAY(-1);) 2025.06.13 15:42:46.360949 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Array aggregate functions require at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:46.367261 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toLastDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT LAST_DAY(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:46.464602 [ 8431 ] {176864ff-5fc2-4505-b6f5-561bcc05e3d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 0, should be 1: In scope SELECT ascii(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 264, line 265) (in query: SELECT ascii();) 2025.06.13 15:42:46.484463 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 0, should be 1: In scope SELECT ascii(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:46.524921 [ 5978 ] {81f57b5f-f526-4d58-bf4b-fd8b645817eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 1, should be 2: In scope SELECT LinfDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 79, line 80) (in query: SELECT LinfDistance(-1);) 2025.06.13 15:42:46.540507 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 1, should be 2: In scope SELECT LinfDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:46.628774 [ 8431 ] {8095f8fa-bd91-4171-969e-2bcabd6904f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 0, should be 1: In scope SELECT asin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 265, line 266) (in query: SELECT asin();) 2025.06.13 15:42:46.640594 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 0, should be 1: In scope SELECT asin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:46.677581 [ 8442 ] {2a2c1f36-2543-4eaf-9f5d-dac37b026252} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 2, should be 1: In scope SELECT parseReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1008, line 1009) (in query: SELECT parseReadableSize(NULL, NULL);) 2025.06.13 15:42:46.689743 [ 5978 ] {1be51271-5e12-4387-8a9f-4175abd00224} executeQuery: Code: 43. DB::Exception: Argument 0 of function LinfNorm should be tuple, got Int8: In scope SELECT LinfNorm(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 80, line 81) (in query: SELECT LinfNorm(-1);) 2025.06.13 15:42:46.703175 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function LinfNorm should be tuple, got Int8: In scope SELECT LinfNorm(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:46.706461 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 2, should be 1: In scope SELECT parseReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:46.752072 [ 8431 ] {49390c03-827c-4f40-9c99-67aac49f9724} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 0, should be 1: In scope SELECT asinh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 266, line 267) (in query: SELECT asinh();) 2025.06.13 15:42:46.765776 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 0, should be 1: In scope SELECT asinh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:46.824129 [ 5978 ] {31834110-74a0-4b88-a6ee-92e571869031} executeQuery: Code: 43. DB::Exception: Argument 0 of function LinfNorm should be tuple, got Int8: In scope SELECT LinfNormalize(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 81, line 82) (in query: SELECT LinfNormalize(-1);) 2025.06.13 15:42:46.830598 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function LinfNorm should be tuple, got Int8: In scope SELECT LinfNormalize(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:46.842081 [ 8442 ] {9b7de5e5-98fb-487b-8609-9c658b2e2a3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1009, line 1010) (in query: SELECT parseReadableSizeOrNull(NULL, NULL);) 2025.06.13 15:42:46.865144 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:46.875515 [ 8431 ] {43f0a49f-1f02-4a7c-880d-179bf8163c21} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 0, should be 1: In scope SELECT assumeNotNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 267, line 268) (in query: SELECT assumeNotNull();) 2025.06.13 15:42:46.903209 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 0, should be 1: In scope SELECT assumeNotNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:46.983231 [ 5978 ] {3c691a28-2146-4402-92ae-2053f015a6f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 1, should be 3: In scope SELECT LpDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 82, line 83) (in query: SELECT LpDistance(-1);) 2025.06.13 15:42:47.012217 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 1, should be 3: In scope SELECT LpDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:47.024491 [ 8442 ] {9a0867bb-46f1-4ddc-952a-d8a17c512ebf} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1010, line 1011) (in query: SELECT parseReadableSizeOrZero(NULL, NULL);) 2025.06.13 15:42:47.052830 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:47.108489 [ 8431 ] {a05a8820-9cc3-4702-a78e-deaefa7cb94a} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 0, should be 1: In scope SELECT atan(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 268, line 269) (in query: SELECT atan();) 2025.06.13 15:42:47.113911 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 0, should be 1: In scope SELECT atan(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:47.130639 [ 5978 ] {2e7198d3-8483-47d3-b60f-e6b50390c06e} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 1, should be 2: In scope SELECT LpNorm(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 83, line 84) (in query: SELECT LpNorm(-1);) 2025.06.13 15:42:47.173503 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 1, should be 2: In scope SELECT LpNorm(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:47.188810 [ 8431 ] {29addecd-46ff-4548-89d0-e0829e6cca77} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 0, should be 2: In scope SELECT atan2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 269, line 270) (in query: SELECT atan2();) 2025.06.13 15:42:47.205461 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 0, should be 2: In scope SELECT atan2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:47.336485 [ 5978 ] {aca5e9c5-6135-42ce-83bb-67fb0737dec1} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 1, should be 2: In scope SELECT LpNormalize(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 84, line 85) (in query: SELECT LpNormalize(-1);) 2025.06.13 15:42:47.337683 [ 8431 ] {9e52a3d8-fd4e-47a7-b308-d7ff9c7a2a83} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 0, should be 1: In scope SELECT atanh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 270, line 271) (in query: SELECT atanh();) 2025.06.13 15:42:47.374909 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 1, should be 2: In scope SELECT LpNormalize(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:47.379958 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 0, should be 1: In scope SELECT atanh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:47.585520 [ 8431 ] {57198f91-f2fc-4bfd-89f3-14bf7628e1c0} executeQuery: Code: 42. DB::Exception: Aggregate function avg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 271, line 272) (in query: SELECT avg();) 2025.06.13 15:42:47.586826 [ 5978 ] {74cf27a3-cb8f-48a6-b75a-c47403b77304} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function MACNumToString, expected UInt64: In scope SELECT MACNumToString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 85, line 86) (in query: SELECT MACNumToString(-1);) 2025.06.13 15:42:47.591082 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function MACNumToString, expected UInt64: In scope SELECT MACNumToString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:47.595931 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function avg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:47.716360 [ 5978 ] {cd2f2682-37b1-465c-89fb-b3786d645374} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function MACStringToNum: In scope SELECT MACStringToNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 86, line 87) (in query: SELECT MACStringToNum(-1);) 2025.06.13 15:42:47.746058 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function MACStringToNum: In scope SELECT MACStringToNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:47.749876 [ 8431 ] {82f296a5-6efb-4da6-b69f-e4ac189d4e6b} executeQuery: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 272, line 273) (in query: SELECT avgWeighted();) 2025.06.13 15:42:47.776213 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:47.870667 [ 8431 ] {d060ae10-c8f3-44ba-aa80-55fda04e57c3} executeQuery: Code: 42. DB::Exception: Function bar requires from 3 or 4 parameters: value, min_value, max_value, [max_width_of_bar = 80]. Passed 0.: In scope SELECT bar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 273, line 274) (in query: SELECT bar();) 2025.06.13 15:42:47.874219 [ 5978 ] {7eab8721-bd16-4c73-9f40-986dc0d6597b} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function MACStringToOUI: In scope SELECT MACStringToOUI(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 87, line 88) (in query: SELECT MACStringToOUI(-1);) 2025.06.13 15:42:47.876246 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function bar requires from 3 or 4 parameters: value, min_value, max_value, [max_width_of_bar = 80]. Passed 0.: In scope SELECT bar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:47.892279 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function MACStringToOUI: In scope SELECT MACStringToOUI(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:48.052901 [ 8442 ] {0ee696cb-36d7-4395-afa6-ef00b462127d} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 2, should be 1: In scope SELECT path(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1014, line 1015) (in query: SELECT path(NULL, NULL);) 2025.06.13 15:42:48.053569 [ 5978 ] {11399294-96a8-4dc2-84bc-9f94c6061987} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 1, should be 2: In scope SELECT MAP_FROM_ARRAYS(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 88, line 89) (in query: SELECT MAP_FROM_ARRAYS(-1);) 2025.06.13 15:42:48.062606 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 2, should be 1: In scope SELECT path(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:48.067062 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 1, should be 2: In scope SELECT MAP_FROM_ARRAYS(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:48.068677 [ 8431 ] {3ac58f9f-6933-4abb-b7d6-50aa386bdb70} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 0, should be 1: In scope SELECT base58Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 274, line 275) (in query: SELECT base58Decode();) 2025.06.13 15:42:48.082862 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 0, should be 1: In scope SELECT base58Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:48.151724 [ 8442 ] {2f199267-8097-4e66-8e06-c5f7017b6f4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 2, should be 1: In scope SELECT pathFull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1015, line 1016) (in query: SELECT pathFull(NULL, NULL);) 2025.06.13 15:42:48.174613 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 2, should be 1: In scope SELECT pathFull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:48.177316 [ 8431 ] {daded00c-77a8-4006-ac1a-d69155afda92} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 0, should be 1: In scope SELECT base58Encode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 275, line 276) (in query: SELECT base58Encode();) 2025.06.13 15:42:48.182223 [ 5978 ] {eb471b85-3fbf-4669-97e3-26b53e160856} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function MD4: In scope SELECT MD4(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 89, line 90) (in query: SELECT MD4(-1);) 2025.06.13 15:42:48.193499 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 0, should be 1: In scope SELECT base58Encode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:48.204067 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function MD4: In scope SELECT MD4(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:48.352460 [ 8431 ] {00259506-e63a-4715-82a5-e0c034b6d7b4} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 276, line 277) (in query: SELECT base64Decode();) 2025.06.13 15:42:48.355517 [ 5978 ] {0e503a34-f97e-41c6-87a7-2013c9c8c0fa} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function MD5: In scope SELECT MD5(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 90, line 91) (in query: SELECT MD5(-1);) 2025.06.13 15:42:48.363451 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function MD5: In scope SELECT MD5(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:48.371534 [ 8431 ] {} 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) 2025.06.13 15:42:48.386355 [ 8442 ] {88a2a044-14a5-49a7-b2bc-c2b846efac96} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1016, line 1017) (in query: SELECT percentRank(NULL, NULL);) 2025.06.13 15:42:48.396846 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:42:48.552163 [ 8431 ] {9adc179f-271c-4564-a63f-27883ca39e09} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 277, line 278) (in query: SELECT base64Encode();) 2025.06.13 15:42:48.560557 [ 8431 ] {} 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) 2025.06.13 15:42:48.580606 [ 5978 ] {73841136-b57c-4e19-93ee-f6f2bdf6875e} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MILLISECOND(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 91, line 92) (in query: SELECT MILLISECOND(-1);) 2025.06.13 15:42:48.598622 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MILLISECOND(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:48.654737 [ 8442 ] {701a2883-d471-4566-8e3f-29797e521603} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1017, line 1018) (in query: SELECT percent_rank(NULL, NULL);) 2025.06.13 15:42:48.663768 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:42:48.705167 [ 8431 ] {17d0c199-7171-4d56-8da3-333965986fba} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 0, should be 1: In scope SELECT base64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 278, line 279) (in query: SELECT base64URLDecode();) 2025.06.13 15:42:48.711360 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 0, should be 1: In scope SELECT base64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:48.742537 [ 5978 ] {92b68124-e8a4-47c5-a803-3bbada72e2b2} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MINUTE(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 92, line 93) (in query: SELECT MINUTE(-1);) 2025.06.13 15:42:48.770584 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MINUTE(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:48.779006 [ 8442 ] {d5cab03e-0859-4328-ad0b-a0c61e6c20ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 2, should be 0: In scope SELECT pi(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1018, line 1019) (in query: SELECT pi(NULL, NULL);) 2025.06.13 15:42:48.795916 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 2, should be 0: In scope SELECT pi(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:48.834022 [ 8431 ] {ed3e5bf7-7ac6-4cc5-96be-f8eb90e2b152} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 0, should be 1: In scope SELECT base64URLEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 279, line 280) (in query: SELECT base64URLEncode();) 2025.06.13 15:42:48.844586 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 0, should be 1: In scope SELECT base64URLEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:48.919274 [ 5978 ] {040f1b5d-cdf0-4c22-9ce3-83bd0a1a7a4b} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MONTH(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 93, line 94) (in query: SELECT MONTH(-1);) 2025.06.13 15:42:48.927554 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MONTH(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:48.960935 [ 8431 ] {c347d1f4-5315-4e3c-8dd8-592af9b6613b} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 0, should be 1: In scope SELECT basename(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 280, line 281) (in query: SELECT basename();) 2025.06.13 15:42:48.975514 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 0, should be 1: In scope SELECT basename(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:49.060852 [ 5978 ] {693ae212-3e56-4ffb-bd46-fce07809831f} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function length: In scope SELECT OCTET_LENGTH(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 94, line 95) (in query: SELECT OCTET_LENGTH(-1);) 2025.06.13 15:42:49.084871 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function length: In scope SELECT OCTET_LENGTH(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:49.100043 [ 8431 ] {4482da59-f977-4130-9f0c-1fa148154d59} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 0, should be 1: In scope SELECT bin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 281, line 282) (in query: SELECT bin();) 2025.06.13 15:42:49.105628 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 0, should be 1: In scope SELECT bin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:49.156528 [ 5978 ] {8827e653-0d2b-4153-8513-472b3ad8b900} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT QUARTER(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 95, line 96) (in query: SELECT QUARTER(-1);) 2025.06.13 15:42:49.180001 [ 8430 ] {c00ec2a7-1896-44cd-a4be-9c218fd01894} DynamicQueryHandler: Code: 271. DB::Exception: Too large uncompressed size: 4294967295. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000001fb7f20f 5. ./build_docker/./src/Compression/CompressionCodecMultiple.cpp:100: DB::CompressionCodecMultiple::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000032dbfc78 6. ./build_docker/./src/Compression/ICompressionCodec.cpp:119: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000032dfa96d 7. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:24: DB::CompressedReadBuffer::nextImpl() @ 0x0000000032d9de5a 8. DB::ReadBuffer::next() @ 0x0000000017e74832 9. ./build_docker/./src/IO/ReadBuffer.cpp:34: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000023b29091 10. DB::ReadBuffer::next() @ 0x0000000017e74832 11. ./src/IO/ReadBuffer.h:96: DB::ConcatReadBuffer::nextImpl() @ 0x000000002d409a00 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. ./src/IO/ReadBuffer.h:81: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8180 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:49.194343 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT QUARTER(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:49.196385 [ 8431 ] {aa286b28-f49e-426f-b7d2-307546ce2ccf} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 0, should be 2: In scope SELECT bitAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 282, line 283) (in query: SELECT bitAnd();) 2025.06.13 15:42:49.202225 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 0, should be 2: In scope SELECT bitAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:49.243012 [ 8431 ] {3844d201-39a1-49ce-b685-039dfe17e386} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 0, should be 1: In scope SELECT bitCount(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 283, line 284) (in query: SELECT bitCount();) 2025.06.13 15:42:49.247487 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 0, should be 1: In scope SELECT bitCount(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:49.318549 [ 2860 ] {944e534f-4bf0-4015-9e31-a9fc857aad4a} DynamicQueryHandler: Code: 246. DB::Exception: Wrong data for compression codec NONE: source_size (278) != uncompressed_size (33686018). (CORRUPTED_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, unsigned int&) @ 0x000000002acd2a0f 5. ./build_docker/./src/Compression/CompressionCodecNone.cpp:33: DB::CompressionCodecNone::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000032db6fa6 6. ./build_docker/./src/Compression/ICompressionCodec.cpp:119: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000032dfa96d 7. ./build_docker/./src/Compression/CompressionCodecMultiple.cpp:114: DB::CompressionCodecMultiple::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000032dbf8c2 8. ./build_docker/./src/Compression/ICompressionCodec.cpp:119: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000032dfa96d 9. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:24: DB::CompressedReadBuffer::nextImpl() @ 0x0000000032d9de5a 10. DB::ReadBuffer::next() @ 0x0000000017e74832 11. ./build_docker/./src/IO/ReadBuffer.cpp:34: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000023b29091 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. ./src/IO/ReadBuffer.h:96: DB::ConcatReadBuffer::nextImpl() @ 0x000000002d409a00 14. DB::ReadBuffer::next() @ 0x0000000017e74832 15. ./src/IO/ReadBuffer.h:81: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8180 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:42:49.492719 [ 8431 ] {bf6e74b1-0f85-4079-94ae-bc6b7bfb3630} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 0, should be 2: In scope SELECT bitHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 284, line 285) (in query: SELECT bitHammingDistance();) 2025.06.13 15:42:49.493074 [ 8432 ] {3d760764-798b-45fd-9a1c-988cc9dabe56} executeQuery: Code: 57. DB::Exception: Table test_9.two_00458 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55844) (comment: 00458_merge_type_cast.sql) (query 70, line 104) (in query: CREATE TABLE two_00458 (x UInt64) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:42:49.508128 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 0, should be 2: In scope SELECT bitHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:49.518858 [ 8432 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.two_00458 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:42:49.564489 [ 5978 ] {cfe8951f-e652-4e78-8584-7cc6db2154d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 1: In scope SELECT REGEXP_EXTRACT(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 96, line 97) (in query: SELECT REGEXP_EXTRACT(-1);) 2025.06.13 15:42:49.573407 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 1: In scope SELECT REGEXP_EXTRACT(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:49.638119 [ 8431 ] {cda95598-9250-4387-8636-d9cc2a688de3} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 0, should be 1: In scope SELECT bitNot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 285, line 286) (in query: SELECT bitNot();) 2025.06.13 15:42:49.699259 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 0, should be 1: In scope SELECT bitNot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:49.710351 [ 5978 ] {78522b77-5dd4-4b81-9420-f178062fbc46} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 1, should be 2: In scope SELECT REGEXP_MATCHES(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 97, line 98) (in query: SELECT REGEXP_MATCHES(-1);) 2025.06.13 15:42:49.736422 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 1, should be 2: In scope SELECT REGEXP_MATCHES(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:49.834666 [ 8431 ] {f8d6ba22-0b7b-415e-b912-98711b072e06} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 0, should be 2: In scope SELECT bitOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 286, line 287) (in query: SELECT bitOr();) 2025.06.13 15:42:49.845028 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 0, should be 2: In scope SELECT bitOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:49.847976 [ 8442 ] {d39ae3d5-4174-44c4-a79b-25c44f37c7fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1023, line 1024) (in query: SELECT polygonAreaCartesian(NULL, NULL);) 2025.06.13 15:42:49.849910 [ 5978 ] {cb51a621-ed8b-47cb-b300-c8da8f1f96c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 1, should be 3: In scope SELECT REGEXP_REPLACE(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 98, line 99) (in query: SELECT REGEXP_REPLACE(-1);) 2025.06.13 15:42:49.856770 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:49.857431 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 1, should be 3: In scope SELECT REGEXP_REPLACE(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:49.909143 [ 8431 ] {7ccce5e7-ce96-424f-b0f7-d4dd3bab211c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 0, should be 1: In scope SELECT bitPositionsToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 287, line 288) (in query: SELECT bitPositionsToArray();) 2025.06.13 15:42:49.913736 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 0, should be 1: In scope SELECT bitPositionsToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:49.925721 [ 5978 ] {0beebf30-78fc-4d27-8d10-6a36e49b4e4c} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function RIPEMD160: In scope SELECT RIPEMD160(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 99, line 100) (in query: SELECT RIPEMD160(-1);) 2025.06.13 15:42:49.957473 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function RIPEMD160: In scope SELECT RIPEMD160(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:49.965457 [ 8442 ] {f38bb7d4-359d-408d-8c99-b1a40e9dbc41} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1024, line 1025) (in query: SELECT polygonAreaSpherical(NULL, NULL);) 2025.06.13 15:42:49.995407 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:50.128033 [ 8431 ] {2ebea526-5fbd-4140-881a-dfa66d22d04f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 0, should be 2: In scope SELECT bitRotateLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 288, line 289) (in query: SELECT bitRotateLeft();) 2025.06.13 15:42:50.132006 [ 5978 ] {267ad9c0-703c-4a78-8184-1537a9b0e161} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT SCHEMA(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 100, line 101) (in query: SELECT SCHEMA(-1);) 2025.06.13 15:42:50.135275 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 0, should be 2: In scope SELECT bitRotateLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:50.148411 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT SCHEMA(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:50.153895 [ 8442 ] {6759715b-8eb7-41e3-8d3f-62c98aa01acc} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1025, line 1026) (in query: SELECT polygonConvexHullCartesian(NULL, NULL);) 2025.06.13 15:42:50.159430 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:50.193319 [ 8431 ] {9f0e0ad6-2092-4e77-b3a0-7e13cb6f51af} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 0, should be 2: In scope SELECT bitRotateRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 289, line 290) (in query: SELECT bitRotateRight();) 2025.06.13 15:42:50.214560 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 0, should be 2: In scope SELECT bitRotateRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:50.215551 [ 5978 ] {d64ed810-c451-40da-98d9-c46923e1fc91} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT SECOND(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 101, line 102) (in query: SELECT SECOND(-1);) 2025.06.13 15:42:50.228438 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT SECOND(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:50.240783 [ 8442 ] {f430c158-963c-4c2d-a81b-6f339c3504b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1026, line 1027) (in query: SELECT polygonPerimeterCartesian(NULL, NULL);) 2025.06.13 15:42:50.245758 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:50.356251 [ 8431 ] {9eda46b0-3e0b-459c-9a38-728ccb756f2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 0, should be 2: In scope SELECT bitShiftLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 290, line 291) (in query: SELECT bitShiftLeft();) 2025.06.13 15:42:50.363831 [ 5978 ] {6a4241c9-5545-4da5-a6c5-ac687e0e3753} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function SHA1: In scope SELECT SHA1(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 102, line 103) (in query: SELECT SHA1(-1);) 2025.06.13 15:42:50.370320 [ 8430 ] {8842d17e-8c9e-4e17-b929-512dbef877aa} executeQuery: Code: 43. DB::Exception: No operation equals between DateTime64(3) and String. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38250) (comment: 01268_DateTime64_in_WHERE.sql) (query 1, line 1) (in query: -- Error cases: -- non-const string column WITH '2020-02-05 14:34:12.333' as S, toDateTime64(S, 3) as DT64 SELECT DT64 = materialize(S);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e335b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:42:50.376141 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 0, should be 2: In scope SELECT bitShiftLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:50.381058 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function SHA1: In scope SELECT SHA1(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:50.404311 [ 8442 ] {299e28f8-0da8-47b3-8da4-ea34c74ed783} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1027, line 1028) (in query: SELECT polygonPerimeterSpherical(NULL, NULL);) 2025.06.13 15:42:50.429227 [ 8431 ] {e3adb52e-ad8d-4c7a-a6ec-90b9230f8b8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 0, should be 2: In scope SELECT bitShiftRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 291, line 292) (in query: SELECT bitShiftRight();) 2025.06.13 15:42:50.457852 [ 8430 ] {} TCPHandler: Code: 43. DB::Exception: No operation equals between DateTime64(3) and String. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e335b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:42:50.459351 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:50.467810 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 0, should be 2: In scope SELECT bitShiftRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:50.564093 [ 5978 ] {a5ffb930-04c6-4651-a6cf-a3d08fc79466} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function SHA224: In scope SELECT SHA224(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 103, line 104) (in query: SELECT SHA224(-1);) 2025.06.13 15:42:50.617217 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function SHA224: In scope SELECT SHA224(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:50.638391 [ 8430 ] {5579ffbf-2dd6-4c82-b6ba-7603892c49b5} executeQuery: Code: 43. DB::Exception: No operation equals between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38250) (comment: 01268_DateTime64_in_WHERE.sql) (query 2, line 4) (in query: WITH '2020-02-05 14:34:12.333' as S, toDateTime64(S, 3) as DT64 SELECT materialize(S) = toDateTime64(S, 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e335b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:42:50.645710 [ 8430 ] {} TCPHandler: Code: 43. DB::Exception: No operation equals between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e335b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:42:50.708778 [ 5978 ] {4f760307-3944-428c-a8b2-d0707391ee6c} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function SHA256: In scope SELECT SHA256(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 104, line 105) (in query: SELECT SHA256(-1);) 2025.06.13 15:42:50.718314 [ 8431 ] {b84591f6-def0-4085-b8ed-3f22c4a1c7a1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT bitSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 292, line 293) (in query: SELECT bitSlice();) 2025.06.13 15:42:50.739562 [ 18380 ] {0a4ba635-1291-4007-a20b-de7a7fe2c2d3} executeQuery: Code: 269. DB::Exception: Cannot add dependencies for 'test_13.test_dict', because it will lead to cyclic dependencies: test_13.test_dict -> [test_13.view]; test_13.view -> [test_13.test_dict]. (INFINITE_LOOP) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38218) (comment: 03173_check_cyclic_dependencies_on_create_and_rename.sql) (query 11, line 22) (in query: CREATE OR REPLACE DICTIONARY test_dict ( id UInt64, value String ) PRIMARY KEY id SOURCE(CLICKHOUSE(TABLE view)) LAYOUT(FLAT()) LIFETIME(MIN 0 MAX 1000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04442f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1594: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&)::$_0::operator()(DB::TablesDependencyGraph&, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002d5fd967 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1604: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002d5fd644 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1493: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dc84b5a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2064: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc77b56 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72316 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:42:50.747967 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT bitSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:50.751766 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function SHA256: In scope SELECT SHA256(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:50.766793 [ 18380 ] {} TCPHandler: Code: 269. DB::Exception: Cannot add dependencies for 'test_13.test_dict', because it will lead to cyclic dependencies: test_13.test_dict -> [test_13.view]; test_13.view -> [test_13.test_dict]. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04442f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1594: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&)::$_0::operator()(DB::TablesDependencyGraph&, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002d5fd967 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1604: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002d5fd644 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1493: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dc84b5a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2064: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc77b56 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72316 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:42:50.842218 [ 5978 ] {3570d4ac-2ae2-41d1-af85-edc9e499ed11} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function SHA384: In scope SELECT SHA384(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 105, line 106) (in query: SELECT SHA384(-1);) 2025.06.13 15:42:50.856960 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function SHA384: In scope SELECT SHA384(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:50.930916 [ 8430 ] {72b20866-5f80-4623-8137-2a6dd23eeda5} executeQuery: Code: 43. DB::Exception: No operation equals between DateTime64(3) and String. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38250) (comment: 01268_DateTime64_in_WHERE.sql) (query 3, line 5) (in query: WITH '2020-02-05 14:34:12.333' as S, toDateTime64(S, 3) as DT64 SELECT * WHERE DT64 = materialize(S);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e335b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 14. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 16. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 17. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:42:50.940283 [ 18380 ] {ccdf5f66-b736-44da-86c8-c4abe00909b2} executeQuery: Code: 269. DB::Exception: Cannot add dependencies for 'test_13.test_dict', because it will lead to cyclic dependencies: test_13.test_dict -> [test_13.view]; test_13.view -> [test_13.test_dict]. (INFINITE_LOOP) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38218) (comment: 03173_check_cyclic_dependencies_on_create_and_rename.sql) (query 12, line 32) (in query: REPLACE DICTIONARY test_dict ( id UInt64, value String ) PRIMARY KEY id SOURCE(CLICKHOUSE(TABLE view)) LAYOUT(FLAT()) LIFETIME(MIN 0 MAX 1000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04442f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1594: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&)::$_0::operator()(DB::TablesDependencyGraph&, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002d5fd967 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1604: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002d5fd644 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1493: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dc84b5a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2064: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc77b56 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72316 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:42:50.941090 [ 8430 ] {} TCPHandler: Code: 43. DB::Exception: No operation equals between DateTime64(3) and String. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e335b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 14. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 16. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 17. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:42:50.976149 [ 18380 ] {} TCPHandler: Code: 269. DB::Exception: Cannot add dependencies for 'test_13.test_dict', because it will lead to cyclic dependencies: test_13.test_dict -> [test_13.view]; test_13.view -> [test_13.test_dict]. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04442f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1594: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&)::$_0::operator()(DB::TablesDependencyGraph&, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002d5fd967 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1604: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002d5fd644 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1493: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dc84b5a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2064: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x000000002dc77b56 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72316 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:42:50.981688 [ 8431 ] {ba6f8770-7728-4e16-a083-24f623a50713} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 0, should be 2: In scope SELECT bitTest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 293, line 294) (in query: SELECT bitTest();) 2025.06.13 15:42:50.985642 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 0, should be 2: In scope SELECT bitTest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:51.025810 [ 5978 ] {7e9673af-1e52-4b7e-9b09-a26cc9d25b07} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function SHA512: In scope SELECT SHA512(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 106, line 107) (in query: SELECT SHA512(-1);) 2025.06.13 15:42:51.037513 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function SHA512: In scope SELECT SHA512(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:51.044486 [ 8430 ] {8283e06e-478f-40d1-b3fd-47115dc7050c} executeQuery: Code: 43. DB::Exception: No operation equals between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38250) (comment: 01268_DateTime64_in_WHERE.sql) (query 4, line 6) (in query: WITH '2020-02-05 14:34:12.333' as S, toDateTime64(S, 3) as DT64 SELECT * WHERE materialize(S) = DT64;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e335b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 14. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 16. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 17. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:42:51.050446 [ 8430 ] {} TCPHandler: Code: 43. DB::Exception: No operation equals between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e335b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 14. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 16. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 17. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:42:51.053861 [ 8431 ] {b780b5f4-1d5a-47b3-b212-44b29afbcaed} executeQuery: Code: 35. DB::Exception: Number of arguments for function bitTestAll doesn't match: passed 0, should be at least 2.: In scope SELECT bitTestAll(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 294, line 295) (in query: SELECT bitTestAll();) 2025.06.13 15:42:51.060443 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function bitTestAll doesn't match: passed 0, should be at least 2.: In scope SELECT bitTestAll(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:51.294837 [ 5978 ] {f8c0306b-bc19-4688-8935-4efd12417319} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function SHA512_256: In scope SELECT SHA512_256(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 107, line 108) (in query: SELECT SHA512_256(-1);) 2025.06.13 15:42:51.308345 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function SHA512_256: In scope SELECT SHA512_256(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:51.314636 [ 8431 ] {4ca6740b-7f9c-41bc-bdfd-2fc1fd273959} executeQuery: Code: 35. DB::Exception: Number of arguments for function bitTestAny doesn't match: passed 0, should be at least 2.: In scope SELECT bitTestAny(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 295, line 296) (in query: SELECT bitTestAny();) 2025.06.13 15:42:51.323341 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function bitTestAny doesn't match: passed 0, should be at least 2.: In scope SELECT bitTestAny(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:51.421452 [ 8431 ] {6b12388a-c749-4683-b7c0-1f5ec74fd872} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 0, should be 2: In scope SELECT bitXor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 296, line 297) (in query: SELECT bitXor();) 2025.06.13 15:42:51.432575 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 0, should be 2: In scope SELECT bitXor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:51.542332 [ 18380 ] {528ecb89-526b-4a40-99a2-7c53028d6aba} executeQuery: Code: 269. DB::Exception: Cannot exchange 'test_13.test_dict' and 'test_13.test_dict_2', because it will lead to cyclic dependencies: test_13.test_dict -> [test_13.view]; test_13.view -> [test_13.test_dict]. (INFINITE_LOOP) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38218) (comment: 03173_check_cyclic_dependencies_on_create_and_rename.sql) (query 15, line 54) (in query: EXCHANGE DICTIONARIES test_dict AND test_dict_2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x000000002d60b76f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1663: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&)::$_0::operator()(DB::TablesDependencyGraph&) const @ 0x000000002d5fe3a3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1674: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&) @ 0x000000002d5fdf60 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:141: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dcf84a6 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dcf6b2c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:42:51.563256 [ 18380 ] {} TCPHandler: Code: 269. DB::Exception: Cannot exchange 'test_13.test_dict' and 'test_13.test_dict_2', because it will lead to cyclic dependencies: test_13.test_dict -> [test_13.view]; test_13.view -> [test_13.test_dict]. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x000000002d60b76f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1663: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&)::$_0::operator()(DB::TablesDependencyGraph&) const @ 0x000000002d5fe3a3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1674: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&) @ 0x000000002d5fdf60 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:141: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dcf84a6 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dcf6b2c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:42:51.564393 [ 8430 ] {a5690a3f-8891-4d96-bb60-0b81d40d8363} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: while converting 'ABCD' to DateTime64(3): In scope SELECT * WHERE toDateTime64(123.345, 3) = 'ABCD'. (CANNOT_PARSE_DATETIME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38250) (comment: 01268_DateTime64_in_WHERE.sql) (query 5, line 8) (in query: SELECT * WHERE toDateTime64(123.345, 3) == 'ABCD';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x0000000023b5017d 6. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x0000000020a92944 7. ./src/IO/ReadHelpers.h:1221: DB::SerializationDateTime64::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5549bd 8. ./build_docker/./src/DataTypes/Serializations/SerializationDateTime64.cpp:65: DB::SerializationDateTime64::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5547a2 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e257bab 10. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 11. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 12. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:42:51.578634 [ 8430 ] {} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: while converting 'ABCD' to DateTime64(3): In scope SELECT * WHERE toDateTime64(123.345, 3) = 'ABCD'. (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x0000000023b5017d 6. void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x0000000020a92944 7. ./src/IO/ReadHelpers.h:1221: DB::SerializationDateTime64::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5549bd 8. ./build_docker/./src/DataTypes/Serializations/SerializationDateTime64.cpp:65: DB::SerializationDateTime64::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5547a2 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e257bab 10. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 11. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 12. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:42:51.663262 [ 8431 ] {75948d29-88ec-4d5a-a62c-a4fb5f25ea2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 0, should be 2: In scope SELECT bitmapAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 297, line 298) (in query: SELECT bitmapAnd();) 2025.06.13 15:42:51.672974 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 0, should be 2: In scope SELECT bitmapAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:51.729274 [ 3821 ] {35972cda-a4a8-4054-8727-027b77cfd959} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38232) (comment: 03095_window_functions_qualify.sql) (query 15, line 30) (in query: SELECT number % toUInt256(2) AS key, count() FROM numbers(10) GROUP BY key WITH CUBE WITH TOTALS QUALIFY key = toNullable(toNullable(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfcadd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:42:51.734169 [ 3821 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfcadd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:42:51.803344 [ 3821 ] {55aea014-7783-4d7d-a293-4154bde09cdb} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38232) (comment: 03095_window_functions_qualify.sql) (query 16, line 32) (in query: SELECT number % 2 AS key, count(materialize(5)) IGNORE NULLS FROM numbers(10) WHERE toLowCardinality(toLowCardinality(materialize(2))) GROUP BY key WITH CUBE WITH TOTALS QUALIFY key = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfcadd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:42:51.810006 [ 3821 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfcadd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:42:51.832927 [ 3821 ] {5e510f68-ec82-4898-b505-6d3d118fd71c} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38232) (comment: 03095_window_functions_qualify.sql) (query 17, line 34) (in query: SELECT 4, count(4) IGNORE NULLS, number % 2 AS key FROM numbers(10) GROUP BY key WITH ROLLUP WITH TOTALS QUALIFY key = materialize(0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfcadd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:42:51.836590 [ 3821 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfcadd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:42:51.852898 [ 8431 ] {97a7fd5b-65af-4db9-bb20-56b60ee5ee22} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapAndCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 298, line 299) (in query: SELECT bitmapAndCardinality();) 2025.06.13 15:42:51.857589 [ 3821 ] {153f3fdb-6ac6-493a-9032-989e99fb1d64} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38232) (comment: 03095_window_functions_qualify.sql) (query 18, line 36) (in query: SELECT 3, number % toLowCardinality(2) AS key, count() IGNORE NULLS FROM numbers(10) GROUP BY key WITH ROLLUP WITH TOTALS QUALIFY key = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfcadd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:42:51.857948 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapAndCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:51.862391 [ 3821 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfcadd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:42:51.937086 [ 8431 ] {8a1d0e48-f54f-46af-89bd-40195c294ccf} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 0, should be 2: In scope SELECT bitmapAndnot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 299, line 300) (in query: SELECT bitmapAndnot();) 2025.06.13 15:42:51.945015 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 0, should be 2: In scope SELECT bitmapAndnot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:51.959646 [ 18380 ] {d8530857-61d7-4bad-9a0d-b7d285e638d5} executeQuery: Code: 269. DB::Exception: Cannot exchange 'test_13.test_dict' and 'test_13.test_dict_2', because it will lead to cyclic dependencies: test_13.test_dict -> [test_13.view]; test_13.view -> [test_13.test_dict]. (INFINITE_LOOP) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38218) (comment: 03173_check_cyclic_dependencies_on_create_and_rename.sql) (query 18, line 68) (in query: EXCHANGE DICTIONARIES test_dict AND test_dict_2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x000000002d60b76f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1663: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&)::$_0::operator()(DB::TablesDependencyGraph&) const @ 0x000000002d5fe3a3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1674: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&) @ 0x000000002d5fdf60 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:141: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dcf84a6 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dcf6b2c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:42:51.982831 [ 5978 ] {ead5a3fa-2dc2-4495-8e54-37c9ca4b2670} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 1, should be 3: In scope SELECT SUBSTRING_INDEX(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 111, line 112) (in query: SELECT SUBSTRING_INDEX(-1);) 2025.06.13 15:42:52.011290 [ 18380 ] {} TCPHandler: Code: 269. DB::Exception: Cannot exchange 'test_13.test_dict' and 'test_13.test_dict_2', because it will lead to cyclic dependencies: test_13.test_dict -> [test_13.view]; test_13.view -> [test_13.test_dict]. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x000000002d60b76f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1663: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&)::$_0::operator()(DB::TablesDependencyGraph&) const @ 0x000000002d5fe3a3 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1674: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&) @ 0x000000002d5fdf60 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:141: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002dcf84a6 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x000000002dcf6b2c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:42:52.015826 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 1, should be 3: In scope SELECT SUBSTRING_INDEX(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:52.137642 [ 8431 ] {8b9d66d7-d6cf-4423-8e58-2bb23f4b8c22} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapAndnotCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 300, line 301) (in query: SELECT bitmapAndnotCardinality();) 2025.06.13 15:42:52.149649 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapAndnotCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:52.153452 [ 5978 ] {d09eabb5-1582-42ac-8c8d-c7552853a19e} executeQuery: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT SVG(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 112, line 113) (in query: SELECT SVG(-1);) 2025.06.13 15:42:52.161582 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT SVG(-1). (BAD_ARGUMENTS) 2025.06.13 15:42:52.195557 [ 18380 ] {35315114-34ee-4e7f-b199-cd26863fcebc} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38218) (comment: 03173_check_cyclic_dependencies_on_create_and_rename.sql) (query 19, line 70) (in query: DROP DICTIONARY test_dict;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:42:52.217930 [ 18380 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:42:52.285816 [ 8431 ] {a641687c-fb04-4b2f-bd8e-81aeeed4aebb} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 0, should be 1: In scope SELECT bitmapBuild(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 301, line 302) (in query: SELECT bitmapBuild();) 2025.06.13 15:42:52.286059 [ 5978 ] {d7b31267-54df-48c0-b3a6-273652dc7b34} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 113, line 114) (in query: SELECT TIMESTAMP_DIFF(-1);) 2025.06.13 15:42:52.293129 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:52.296867 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 0, should be 1: In scope SELECT bitmapBuild(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:52.372872 [ 8431 ] {9c57e144-e4ae-446b-ad63-44b900d991f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 0, should be 1: In scope SELECT bitmapCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 302, line 303) (in query: SELECT bitmapCardinality();) 2025.06.13 15:42:52.396528 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 0, should be 1: In scope SELECT bitmapCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:52.421076 [ 5978 ] {5a5aea8f-f84e-4112-ac6f-4a09cf8b6c5a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Encode'. Expected: String or FixedString, got: Int8: In scope SELECT TO_BASE64(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 114, line 115) (in query: SELECT TO_BASE64(-1);) 2025.06.13 15:42:52.435332 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Encode'. Expected: String or FixedString, got: Int8: In scope SELECT TO_BASE64(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:52.490478 [ 8431 ] {330c41b6-4f2a-4006-8829-ca0b505aa79f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 0, should be 2: In scope SELECT bitmapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 303, line 304) (in query: SELECT bitmapContains();) 2025.06.13 15:42:52.498873 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 0, should be 2: In scope SELECT bitmapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:52.558960 [ 5978 ] {6781925f-2812-4835-a993-3e0054d3113a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT TO_DAYS(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 115, line 116) (in query: SELECT TO_DAYS(-1);) 2025.06.13 15:42:52.573766 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT TO_DAYS(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:52.628444 [ 8431 ] {10e8f62c-6530-45d2-a2c6-e46ead49eadf} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 0, should be 2: In scope SELECT bitmapHasAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 304, line 305) (in query: SELECT bitmapHasAll();) 2025.06.13 15:42:52.641527 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 0, should be 2: In scope SELECT bitmapHasAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:52.719924 [ 5978 ] {aab386e8-9b2b-4aee-b373-f2b75a737432} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Int8: In scope SELECT TO_UNIXTIME(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 116, line 117) (in query: SELECT TO_UNIXTIME(-1);) 2025.06.13 15:42:52.728034 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Int8: In scope SELECT TO_UNIXTIME(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:52.749595 [ 8431 ] {b8b574f2-9c78-4c62-bb49-e483a84e0317} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 0, should be 2: In scope SELECT bitmapHasAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 305, line 306) (in query: SELECT bitmapHasAny();) 2025.06.13 15:42:52.761014 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 0, should be 2: In scope SELECT bitmapHasAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:52.897494 [ 5978 ] {6a6dda2d-df56-4076-8580-aae8b09ceff9} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 117, line 118) (in query: SELECT ULIDStringToDateTime(-1);) 2025.06.13 15:42:52.912242 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:52.939150 [ 8431 ] {475484d7-7518-40a2-bf1c-df828bbb5551} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 0, should be 1: In scope SELECT bitmapMax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 306, line 307) (in query: SELECT bitmapMax();) 2025.06.13 15:42:52.956537 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 0, should be 1: In scope SELECT bitmapMax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:53.054231 [ 5978 ] {25e62112-1da9-4a7b-932a-0f60a362c997} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function URLHash: In scope SELECT URLHash(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 118, line 119) (in query: SELECT URLHash(-1);) 2025.06.13 15:42:53.057674 [ 8431 ] {cedf47bd-b63e-4ffb-91a0-2cdc9f0adfac} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 0, should be 1: In scope SELECT bitmapMin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 307, line 308) (in query: SELECT bitmapMin();) 2025.06.13 15:42:53.065553 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function URLHash: In scope SELECT URLHash(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:53.070567 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 0, should be 1: In scope SELECT bitmapMin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:53.180998 [ 8431 ] {b12a2b38-9cc2-4e22-a7b8-f4944f58e46e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 0, should be 2: In scope SELECT bitmapOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 308, line 309) (in query: SELECT bitmapOr();) 2025.06.13 15:42:53.187949 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 0, should be 2: In scope SELECT bitmapOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:53.233160 [ 5978 ] {6314e223-e2aa-423f-b3e3-51311a9b33a3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'URLHierarchy'. Expected: String, got: Int8: In scope SELECT URLHierarchy(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 119, line 120) (in query: SELECT URLHierarchy(-1);) 2025.06.13 15:42:53.244433 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'URLHierarchy'. Expected: String, got: Int8: In scope SELECT URLHierarchy(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:53.279300 [ 8431 ] {32952db3-f937-4d9d-b311-b17ec99a44e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapOrCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 309, line 310) (in query: SELECT bitmapOrCardinality();) 2025.06.13 15:42:53.292107 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapOrCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:53.471518 [ 8431 ] {d0fefa88-29b2-40d0-a65a-b8873f0fa146} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 0, should be 3: In scope SELECT bitmapSubsetInRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 310, line 311) (in query: SELECT bitmapSubsetInRange();) 2025.06.13 15:42:53.471688 [ 5978 ] {fe9a5f18-7614-46e4-9927-7f0a05a9ae5e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'URLPathHierarchy'. Expected: String, got: Int8: In scope SELECT URLPathHierarchy(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 120, line 121) (in query: SELECT URLPathHierarchy(-1);) 2025.06.13 15:42:53.493150 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'URLPathHierarchy'. Expected: String, got: Int8: In scope SELECT URLPathHierarchy(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:53.549913 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 0, should be 3: In scope SELECT bitmapSubsetInRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:53.608747 [ 8431 ] {f1d4e18c-e526-44b8-9d63-6eee41a9fc5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 0, should be 3: In scope SELECT bitmapSubsetLimit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 311, line 312) (in query: SELECT bitmapSubsetLimit();) 2025.06.13 15:42:53.609039 [ 5978 ] {be8dd213-3f62-4d15-a4ee-e924b8954272} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 1, should be 0: In scope SELECT UTCTimestamp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 121, line 122) (in query: SELECT UTCTimestamp(-1);) 2025.06.13 15:42:53.626723 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 0, should be 3: In scope SELECT bitmapSubsetLimit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:53.633029 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 1, should be 0: In scope SELECT UTCTimestamp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:53.794066 [ 8431 ] {348f62f2-fddc-4d82-83a1-f97907fb499c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 0, should be 1: In scope SELECT bitmapToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 312, line 313) (in query: SELECT bitmapToArray();) 2025.06.13 15:42:53.795519 [ 5978 ] {e1a91e25-fd9f-4e70-9787-38fd40cc4e6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 1, should be 0: In scope SELECT UTC_timestamp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 122, line 123) (in query: SELECT UTC_timestamp(-1);) 2025.06.13 15:42:53.897615 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 0, should be 1: In scope SELECT bitmapToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:53.904394 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 1, should be 0: In scope SELECT UTC_timestamp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:54.005422 [ 8431 ] {0ddb3c6f-2f41-4e7b-98a4-63afd7f086e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 0, should be 3: In scope SELECT bitmapTransform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 313, line 314) (in query: SELECT bitmapTransform();) 2025.06.13 15:42:54.017665 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 0, should be 3: In scope SELECT bitmapTransform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:54.022469 [ 5978 ] {a46cdf2e-9b29-4aac-a10f-83ab6de72aed} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function UUIDNumToString, expected FixedString(16): In scope SELECT UUIDNumToString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 123, line 124) (in query: SELECT UUIDNumToString(-1);) 2025.06.13 15:42:54.033843 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function UUIDNumToString, expected FixedString(16): In scope SELECT UUIDNumToString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:54.139387 [ 8431 ] {548bc61e-75bb-402d-8fce-2b97bcbe0764} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 0, should be 2: In scope SELECT bitmapXor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 314, line 315) (in query: SELECT bitmapXor();) 2025.06.13 15:42:54.149945 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 0, should be 2: In scope SELECT bitmapXor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:54.203252 [ 5978 ] {1a692596-310d-42bf-82cc-ff15522efc6e} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function UUIDStringToNum, expected FixedString(36): In scope SELECT UUIDStringToNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 124, line 125) (in query: SELECT UUIDStringToNum(-1);) 2025.06.13 15:42:54.209544 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function UUIDStringToNum, expected FixedString(36): In scope SELECT UUIDStringToNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:54.257607 [ 8431 ] {3a6ac929-2818-4b21-bd26-f3d3915af920} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapXorCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 315, line 316) (in query: SELECT bitmapXorCardinality();) 2025.06.13 15:42:54.265661 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapXorCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:54.273349 [ 5978 ] {9142992e-13ed-47a9-aba2-e35f036ea075} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function UUIDToNum, expected UUID: In scope SELECT UUIDToNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 125, line 126) (in query: SELECT UUIDToNum(-1);) 2025.06.13 15:42:54.282711 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function UUIDToNum, expected UUID: In scope SELECT UUIDToNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:54.377440 [ 5978 ] {c1e47cae-212b-49ba-964d-0a9644daa548} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function UUIDv7ToDateTime, expected UUID: In scope SELECT UUIDv7ToDateTime(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 126, line 127) (in query: SELECT UUIDv7ToDateTime(-1);) 2025.06.13 15:42:54.390028 [ 8431 ] {f791bdc9-6d71-4ad6-bf40-a2adbc99e70c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 0, should be 1: In scope SELECT bitmaskToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 316, line 317) (in query: SELECT bitmaskToArray();) 2025.06.13 15:42:54.392087 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function UUIDv7ToDateTime, expected UUID: In scope SELECT UUIDv7ToDateTime(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:54.399617 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 0, should be 1: In scope SELECT bitmaskToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:54.573523 [ 8431 ] {3e29f592-0c1e-4ce1-a563-f5ab8c6fd260} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 0, should be 1: In scope SELECT bitmaskToList(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 317, line 318) (in query: SELECT bitmaskToList();) 2025.06.13 15:42:54.584947 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 0, should be 1: In scope SELECT bitmaskToList(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:54.809369 [ 4171 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:42:54.817640 [ 4171 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:42:55.016439 [ 8442 ] {ec073659-84c5-481e-aa4a-18d2160ae7e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 2, should be 6: In scope SELECT proportionsZTest(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1050, line 1051) (in query: SELECT proportionsZTest(NULL, NULL);) 2025.06.13 15:42:55.016645 [ 5978 ] {a8ec8bf3-6c05-4630-b355-fcac12a0dde0} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT YEAR(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 129, line 130) (in query: SELECT YEAR(-1);) 2025.06.13 15:42:55.031359 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 2, should be 6: In scope SELECT proportionsZTest(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:55.033958 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT YEAR(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:55.134673 [ 4171 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:42:55.136372 [ 4171 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:42:55.209367 [ 8442 ] {ebabd9e2-5f07-44bd-bc30-6995350b308a} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 2, should be 1: In scope SELECT protocol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1051, line 1052) (in query: SELECT protocol(NULL, NULL);) 2025.06.13 15:42:55.230960 [ 8431 ] {c1ef4f3a-b98b-4807-8ee5-f3dc5411c1b3} executeQuery: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 321, line 322) (in query: SELECT boundingRatio();) 2025.06.13 15:42:55.236943 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 2, should be 1: In scope SELECT protocol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:55.244172 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:55.329100 [ 8442 ] {1c852691-4da4-4605-b597-0a689c012bca} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 2, should be 1: In scope SELECT punycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1052, line 1053) (in query: SELECT punycodeDecode(NULL, NULL);) 2025.06.13 15:42:55.356039 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 2, should be 1: In scope SELECT punycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:55.517076 [ 8442 ] {6eb40b4f-f331-449f-90cf-ae623c1db6df} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 2, should be 1: In scope SELECT punycodeEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1053, line 1054) (in query: SELECT punycodeEncode(NULL, NULL);) 2025.06.13 15:42:55.524349 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 2, should be 1: In scope SELECT punycodeEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:55.613222 [ 8431 ] {2216f29c-e9c8-42f6-b89c-0fd043e7d648} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 0, should be 2: In scope SELECT byteHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 323, line 324) (in query: SELECT byteHammingDistance();) 2025.06.13 15:42:55.613392 [ 9636 ] {ac28f864-e1a4-4f1f-8036-e3fbb4227d39} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_inference' in scope SELECT * FROM t_json_inference. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58164) (comment: 01825_type_json_schema_inference.sh) (query 1, line 1) (in query: SELECT * FROM t_json_inference FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:42:55.630394 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 0, should be 2: In scope SELECT byteHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:55.632319 [ 9636 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_inference' in scope SELECT * FROM t_json_inference. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:42:55.865618 [ 8431 ] {95179d52-1167-405c-9c6d-32c8c0a7cb1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT byteSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 325, line 326) (in query: SELECT byteSlice();) 2025.06.13 15:42:55.886043 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT byteSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:55.989006 [ 5978 ] {4d06080b-c1ca-429b-83e6-21d89a77ec3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 1, should be 2: In scope SELECT _CAST(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 134, line 135) (in query: SELECT _CAST(-1);) 2025.06.13 15:42:56.010076 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 1, should be 2: In scope SELECT _CAST(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:56.028592 [ 8431 ] {6f3d8ef2-b4de-4c11-b7da-0eb54a3a7b13} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 0, should be 1: In scope SELECT byteSwap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 326, line 327) (in query: SELECT byteSwap();) 2025.06.13 15:42:56.038938 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 0, should be 1: In scope SELECT byteSwap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:56.199771 [ 5978 ] {a81ac890-830f-4760-9f5b-4e8d3e81a1e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 1, should be 2: In scope SELECT __actionName(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 135, line 136) (in query: SELECT __actionName(-1);) 2025.06.13 15:42:56.205452 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 1, should be 2: In scope SELECT __actionName(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:56.210375 [ 8431 ] {6625a506-ce8e-4bcb-a4ea-cccc301161ec} executeQuery: Code: 35. DB::Exception: Function caseWithExpression expects at least 1 arguments: In scope SELECT caseWithExpr(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 327, line 328) (in query: SELECT caseWithExpr();) 2025.06.13 15:42:56.229996 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function caseWithExpression expects at least 1 arguments: In scope SELECT caseWithExpr(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:56.298576 [ 8430 ] {27a80cee-c094-473f-9ae6-624e9ed122aa} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_inference' in scope SELECT toTypeName(obj) FROM t_json_inference LIMIT 1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58178) (comment: 01825_type_json_schema_inference.sh) (query 1, line 1) (in query: SELECT toTypeName(obj) FROM t_json_inference LIMIT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:42:56.319469 [ 8430 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_inference' in scope SELECT toTypeName(obj) FROM t_json_inference LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:42:56.333311 [ 5978 ] {7398dfbf-5893-4626-89ae-68491b11695c} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 1, should be 2: In scope SELECT __bitBoolMaskAnd(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 136, line 137) (in query: SELECT __bitBoolMaskAnd(-1);) 2025.06.13 15:42:56.334691 [ 8431 ] {6bf8217b-db43-4dfd-beaf-7537177efd5e} executeQuery: Code: 35. DB::Exception: Function caseWithExpression expects at least 1 arguments: In scope SELECT caseWithExpression(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 328, line 329) (in query: SELECT caseWithExpression();) 2025.06.13 15:42:56.357061 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function caseWithExpression expects at least 1 arguments: In scope SELECT caseWithExpression(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:56.357730 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 1, should be 2: In scope SELECT __bitBoolMaskAnd(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:56.460197 [ 5978 ] {d7fc092f-0639-43bb-90c1-40d4d705348d} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 1, should be 2: In scope SELECT __bitBoolMaskOr(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 137, line 138) (in query: SELECT __bitBoolMaskOr(-1);) 2025.06.13 15:42:56.476391 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 1, should be 2: In scope SELECT __bitBoolMaskOr(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:56.478454 [ 8431 ] {43f8a9f7-b093-47a9-9794-99e967be1bdf} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 329, line 330) (in query: SELECT caseWithoutExpr();) 2025.06.13 15:42:56.496725 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:56.605199 [ 5978 ] {df0226b2-b31e-4aff-bc8b-e36ab7c34092} executeQuery: Code: 36. DB::Exception: It's a bug! Only UInt8 type is supported by __bitSwapLastTwo.: In scope SELECT __bitSwapLastTwo(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 138, line 139) (in query: SELECT __bitSwapLastTwo(-1);) 2025.06.13 15:42:56.613177 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: It's a bug! Only UInt8 type is supported by __bitSwapLastTwo.: In scope SELECT __bitSwapLastTwo(-1). (BAD_ARGUMENTS) 2025.06.13 15:42:56.646618 [ 8431 ] {37a9a1b8-befe-4959-b167-b30d1155047c} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 330, line 331) (in query: SELECT caseWithoutExpression();) 2025.06.13 15:42:56.653552 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:56.804155 [ 8431 ] {1742c8d6-7864-4099-9a83-23b2025ad404} executeQuery: Code: 35. DB::Exception: Function catboostEvaluate expects at least 2 arguments: In scope SELECT catboostEvaluate(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 331, line 332) (in query: SELECT catboostEvaluate();) 2025.06.13 15:42:56.812665 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function catboostEvaluate expects at least 2 arguments: In scope SELECT catboostEvaluate(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:56.821299 [ 5978 ] {df79f89c-5fa1-4070-9973-4c205140429c} executeQuery: Code: 43. DB::Exception: Function __getScalar accepts one const string argument: In scope SELECT __getScalar(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 140, line 141) (in query: SELECT __getScalar(-1);) 2025.06.13 15:42:56.836608 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function __getScalar accepts one const string argument: In scope SELECT __getScalar(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:57.030074 [ 8431 ] {c74d53eb-718b-424f-9486-7ee6a2b7afa0} executeQuery: Code: 42. DB::Exception: Aggregate function categoricalInformationValue requires two or more arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 332, line 333) (in query: SELECT categoricalInformationValue();) 2025.06.13 15:42:57.043278 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function categoricalInformationValue requires two or more arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:57.138849 [ 8431 ] {1a35164e-ff1e-40df-8aa8-c070f3ec000d} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 0, should be 1: In scope SELECT cbrt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 333, line 334) (in query: SELECT cbrt();) 2025.06.13 15:42:57.155410 [ 9636 ] {1e8da757-fb24-41cc-881f-beb2103457c4} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing): In scope SELECT initializeAggregation('sumMap', [1, 2, 1], [1, 1, 1], [NULL, NULL, NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58200) (comment: 01634_sum_map_nulls.sql) (query 3, line 3) (in query: SELECT initializeAggregation('sumMap', [1, 2, 1], [1, 1, 1], [null, null, null]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: DB::registerAggregateFunctionSumMap(DB::AggregateFunctionFactory&)::$_0::operator()(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) const @ 0x0000000026a5f1a1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:451: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002836285d 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4987 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 11. DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c1fed63 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:42:57.157716 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 0, should be 1: In scope SELECT cbrt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:57.159899 [ 9636 ] {} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing): In scope SELECT initializeAggregation('sumMap', [1, 2, 1], [1, 1, 1], [NULL, NULL, NULL]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: DB::registerAggregateFunctionSumMap(DB::AggregateFunctionFactory&)::$_0::operator()(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) const @ 0x0000000026a5f1a1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:451: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002836285d 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4987 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 11. DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c1fed63 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:42:57.294218 [ 5978 ] {3a850598-cf29-4697-9dfb-5e72f980f721} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 1, should be 2: In scope SELECT accurateCast(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 143, line 144) (in query: SELECT accurateCast(-1);) 2025.06.13 15:42:57.294560 [ 8431 ] {6a80bb3c-adf3-4f3d-8c19-eeed02ec6ad8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT ceil(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 334, line 335) (in query: SELECT ceil();) 2025.06.13 15:42:57.302730 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT ceil(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:57.304138 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 1, should be 2: In scope SELECT accurateCast(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:57.407285 [ 8431 ] {d1dfef4d-ef33-451d-bb92-3acf58b665ef} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT ceiling(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 335, line 336) (in query: SELECT ceiling();) 2025.06.13 15:42:57.407914 [ 5978 ] {09c0fde4-1691-4190-a80e-1bf23f0aaacf} executeQuery: Code: 42. DB::Exception: Function accurateCastOrDefault expected 2 or 3 arguments. Actual 1: In scope SELECT accurateCastOrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 144, line 145) (in query: SELECT accurateCastOrDefault(-1);) 2025.06.13 15:42:57.428463 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function accurateCastOrDefault expected 2 or 3 arguments. Actual 1: In scope SELECT accurateCastOrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:57.429043 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT ceiling(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:57.550924 [ 8431 ] {2ce28923-5b6a-4f95-8d14-ccecb45d1811} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 0, should be 2: In scope SELECT changeDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 336, line 337) (in query: SELECT changeDay();) 2025.06.13 15:42:57.564471 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 0, should be 2: In scope SELECT changeDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:57.622770 [ 5978 ] {2933ea04-ceeb-4539-bfb7-ddb920cdad61} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 1, should be 2: In scope SELECT accurateCastOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 145, line 146) (in query: SELECT accurateCastOrNull(-1);) 2025.06.13 15:42:57.630374 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 1, should be 2: In scope SELECT accurateCastOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:57.698310 [ 8431 ] {2631c82b-ac4a-4a98-a0ba-d265810c8d04} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 0, should be 2: In scope SELECT changeHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 337, line 338) (in query: SELECT changeHour();) 2025.06.13 15:42:57.708800 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 0, should be 2: In scope SELECT changeHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:57.795493 [ 18380 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:42:57.798281 [ 18380 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:42:57.837146 [ 8431 ] {f4e6167b-b80c-49a6-9cc7-f7ff64e146ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 0, should be 2: In scope SELECT changeMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 338, line 339) (in query: SELECT changeMinute();) 2025.06.13 15:42:57.848951 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 0, should be 2: In scope SELECT changeMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:57.938798 [ 8431 ] {69100acb-73b5-4705-b379-471148fcfb7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 0, should be 2: In scope SELECT changeMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 339, line 340) (in query: SELECT changeMonth();) 2025.06.13 15:42:57.950634 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 0, should be 2: In scope SELECT changeMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:58.023332 [ 5978 ] {83a07680-e476-433f-94e8-7e4b009c47e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 1, should be 2: In scope SELECT addDate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 148, line 149) (in query: SELECT addDate(-1);) 2025.06.13 15:42:58.042248 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 1, should be 2: In scope SELECT addDate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:58.043777 [ 8431 ] {52b84651-4ed5-46c6-af28-67f0ea076a0d} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 0, should be 2: In scope SELECT changeSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 340, line 341) (in query: SELECT changeSecond();) 2025.06.13 15:42:58.103737 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 0, should be 2: In scope SELECT changeSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:58.177167 [ 5978 ] {e5a2dd4e-cff9-4def-a40d-b3168a098683} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDays doesn't match: passed 1, should be 2 or 3: In scope SELECT addDays(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 149, line 150) (in query: SELECT addDays(-1);) 2025.06.13 15:42:58.184047 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDays doesn't match: passed 1, should be 2 or 3: In scope SELECT addDays(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:58.190437 [ 8431 ] {1f0f6627-78da-4649-afbb-b332773757bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 0, should be 2: In scope SELECT changeYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 341, line 342) (in query: SELECT changeYear();) 2025.06.13 15:42:58.212173 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 0, should be 2: In scope SELECT changeYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:58.303936 [ 5978 ] {37420dbc-32c1-4e70-b754-9c90f722019a} executeQuery: Code: 42. DB::Exception: Number of arguments for function addHours doesn't match: passed 1, should be 2 or 3: In scope SELECT addHours(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 150, line 151) (in query: SELECT addHours(-1);) 2025.06.13 15:42:58.311000 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addHours doesn't match: passed 1, should be 2 or 3: In scope SELECT addHours(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:58.320524 [ 8431 ] {d7dab8d4-e85b-4e55-8339-2a9bcb266884} executeQuery: Code: 35. DB::Exception: Number of arguments for function char can't be 0, should be at least 1: In scope SELECT char(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 342, line 343) (in query: SELECT char();) 2025.06.13 15:42:58.347229 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function char can't be 0, should be at least 1: In scope SELECT char(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:42:58.486918 [ 5978 ] {351f98d9-b0a1-4f76-b1c1-fc5e9a90e6a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 1, should be 2: In scope SELECT addInterval(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 151, line 152) (in query: SELECT addInterval(-1);) 2025.06.13 15:42:58.514947 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 1, should be 2: In scope SELECT addInterval(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:58.649730 [ 5978 ] {4be33a76-9b5a-4e31-9be9-85561352f29b} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMicroseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addMicroseconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 152, line 153) (in query: SELECT addMicroseconds(-1);) 2025.06.13 15:42:58.688963 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMicroseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addMicroseconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:58.723589 [ 8431 ] {c62acd77-7bf4-4f53-902b-ea57deb40a9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 0, should be 3: In scope SELECT clamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 344, line 345) (in query: SELECT clamp();) 2025.06.13 15:42:58.736286 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 0, should be 3: In scope SELECT clamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:58.786982 [ 5978 ] {417d5f1e-1059-4afc-b287-de17326413e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMilliseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addMilliseconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 153, line 154) (in query: SELECT addMilliseconds(-1);) 2025.06.13 15:42:58.794817 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMilliseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addMilliseconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:58.998714 [ 5978 ] {167206fb-1e8c-450a-83da-cd04ea6f33ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMinutes doesn't match: passed 1, should be 2 or 3: In scope SELECT addMinutes(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 154, line 155) (in query: SELECT addMinutes(-1);) 2025.06.13 15:42:59.011228 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMinutes doesn't match: passed 1, should be 2 or 3: In scope SELECT addMinutes(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:59.017816 [ 8431 ] {5ce7b98c-4387-4237-936a-41150d6ee8fb} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 346, line 347) (in query: SELECT compareSubstrings();) 2025.06.13 15:42:59.029696 [ 8431 ] {} 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) 2025.06.13 15:42:59.136236 [ 5978 ] {bad5db51-586e-48ff-b3f0-d3d9ba8b476a} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMonths doesn't match: passed 1, should be 2 or 3: In scope SELECT addMonths(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 155, line 156) (in query: SELECT addMonths(-1);) 2025.06.13 15:42:59.150193 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMonths doesn't match: passed 1, should be 2 or 3: In scope SELECT addMonths(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:59.349164 [ 5978 ] {93c01a7c-e0e2-4535-9ab2-a03b9bfe1b18} executeQuery: Code: 42. DB::Exception: Number of arguments for function addNanoseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addNanoseconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 156, line 157) (in query: SELECT addNanoseconds(-1);) 2025.06.13 15:42:59.400765 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addNanoseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addNanoseconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:59.669002 [ 8431 ] {051f9398-33b7-45b7-acf6-02d8c4d1f7da} executeQuery: Code: 42. DB::Exception: Number of arguments for function concatWithSeparator doesn't match: passed 0, should be at least 1: In scope SELECT concatWithSeparator(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 349, line 350) (in query: SELECT concatWithSeparator();) 2025.06.13 15:42:59.671859 [ 5978 ] {afae52c8-13f5-4cc4-82fa-5ab12cf1f72a} executeQuery: Code: 42. DB::Exception: Number of arguments for function addQuarters doesn't match: passed 1, should be 2 or 3: In scope SELECT addQuarters(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 157, line 158) (in query: SELECT addQuarters(-1);) 2025.06.13 15:42:59.684194 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function concatWithSeparator doesn't match: passed 0, should be at least 1: In scope SELECT concatWithSeparator(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:59.685710 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addQuarters doesn't match: passed 1, should be 2 or 3: In scope SELECT addQuarters(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:59.778748 [ 8431 ] {afff6fd4-c79f-4010-8e66-59f5e0bed1b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function concatWithSeparatorAssumeInjective doesn't match: passed 0, should be at least 1: In scope SELECT concatWithSeparatorAssumeInjective(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 350, line 351) (in query: SELECT concatWithSeparatorAssumeInjective();) 2025.06.13 15:42:59.790492 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function concatWithSeparatorAssumeInjective doesn't match: passed 0, should be at least 1: In scope SELECT concatWithSeparatorAssumeInjective(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:59.796203 [ 5978 ] {cc0f67bd-c94d-4d0d-9118-6a7ecc34fe11} executeQuery: Code: 42. DB::Exception: Number of arguments for function addSeconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addSeconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 158, line 159) (in query: SELECT addSeconds(-1);) 2025.06.13 15:42:59.812272 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addSeconds doesn't match: passed 1, should be 2 or 3: In scope SELECT addSeconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:59.886296 [ 8442 ] {a9c2d83e-35f0-4336-a2d1-b5e6ed63fc4c} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1072, line 1073) (in query: SELECT quantiles(NULL, NULL);) 2025.06.13 15:42:59.896878 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:42:59.906610 [ 8431 ] {4c702267-8d47-4d23-b119-f8744267fca6} executeQuery: Code: 42. DB::Exception: Number of arguments for function concatWithSeparator doesn't match: passed 0, should be at least 1: In scope SELECT concat_ws(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 351, line 352) (in query: SELECT concat_ws();) 2025.06.13 15:42:59.921408 [ 5978 ] {0414ced8-e7a4-459e-a11e-5abd757c8698} executeQuery: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 1, should be 2: In scope SELECT addTupleOfIntervals(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 159, line 160) (in query: SELECT addTupleOfIntervals(-1);) 2025.06.13 15:42:59.938330 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 1, should be 2: In scope SELECT addTupleOfIntervals(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:42:59.940569 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function concatWithSeparator doesn't match: passed 0, should be at least 1: In scope SELECT concat_ws(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:00.070189 [ 5978 ] {15c85229-6db9-4d41-a3e6-dee0d0a825fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function addWeeks doesn't match: passed 1, should be 2 or 3: In scope SELECT addWeeks(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 160, line 161) (in query: SELECT addWeeks(-1);) 2025.06.13 15:43:00.086024 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addWeeks doesn't match: passed 1, should be 2 or 3: In scope SELECT addWeeks(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:00.152804 [ 8442 ] {ad1bfe4a-db04-46fb-bbdf-9543fae18dd3} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1073, line 1074) (in query: SELECT quantilesBFloat16(NULL, NULL);) 2025.06.13 15:43:00.160167 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:00.196301 [ 5978 ] {0cde8543-560a-4a87-8f78-96cf757b0509} executeQuery: Code: 42. DB::Exception: Number of arguments for function addYears doesn't match: passed 1, should be 2 or 3: In scope SELECT addYears(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 161, line 162) (in query: SELECT addYears(-1);) 2025.06.13 15:43:00.213340 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addYears doesn't match: passed 1, should be 2 or 3: In scope SELECT addYears(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:00.292118 [ 5978 ] {41744b04-3a88-486f-97ed-795766bb1f85} executeQuery: Code: 43. DB::Exception: The only argument for function addressToLine must be UInt64. Found Int8 instead.: In scope SELECT addressToLine(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 162, line 163) (in query: SELECT addressToLine(-1);) 2025.06.13 15:43:00.343121 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The only argument for function addressToLine must be UInt64. Found Int8 instead.: In scope SELECT addressToLine(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:00.356865 [ 8431 ] {a42b39eb-fb1f-4d98-b0c0-d70217433246} executeQuery: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 354, line 355) (in query: SELECT contingency();) 2025.06.13 15:43:00.376444 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:00.401584 [ 8442 ] {53643ebb-17de-445d-aa51-c9d2210c4542} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1075, line 1076) (in query: SELECT quantilesDD(NULL, NULL);) 2025.06.13 15:43:00.420670 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:00.456548 [ 5978 ] {82f1cb43-a6f1-4b0e-a4e3-064aa8012968} executeQuery: Code: 43. DB::Exception: The only argument for function addressToLineWithInlines must be UInt64. Found Int8 instead.: In scope SELECT addressToLineWithInlines(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 163, line 164) (in query: SELECT addressToLineWithInlines(-1);) 2025.06.13 15:43:00.471726 [ 8431 ] {54c20b9a-afc3-4426-9dc3-720021b4ee47} executeQuery: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 0, should be 3: In scope SELECT convertCharset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 355, line 356) (in query: SELECT convertCharset();) 2025.06.13 15:43:00.508479 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The only argument for function addressToLineWithInlines must be UInt64. Found Int8 instead.: In scope SELECT addressToLineWithInlines(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:00.511339 [ 8442 ] {cf072d02-a1c1-4b68-8972-c08b68893254} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1076, line 1077) (in query: SELECT quantilesDeterministic(NULL, NULL);) 2025.06.13 15:43:00.516729 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:00.519435 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 0, should be 3: In scope SELECT convertCharset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:00.623063 [ 8442 ] {41d7fd82-259c-4fad-b0be-13e725148547} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1077, line 1078) (in query: SELECT quantilesExact(NULL, NULL);) 2025.06.13 15:43:00.645544 [ 5978 ] {5f47c68a-c910-40ab-ae4b-5de23ad0ae9d} executeQuery: Code: 43. DB::Exception: The only argument for function addressToSymbol must be UInt64. Found Int8 instead.: In scope SELECT addressToSymbol(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 164, line 165) (in query: SELECT addressToSymbol(-1);) 2025.06.13 15:43:00.651201 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:00.669954 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The only argument for function addressToSymbol must be UInt64. Found Int8 instead.: In scope SELECT addressToSymbol(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:00.672236 [ 8431 ] {8bc6ede4-2ef8-4865-a2ff-06b1a4e35160} executeQuery: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 356, line 357) (in query: SELECT corr();) 2025.06.13 15:43:00.742712 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:00.863123 [ 5978 ] {cdddd68a-a0a2-4c41-86c8-0b4913df9c96} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_decrypt_mysql(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 165, line 166) (in query: SELECT aes_decrypt_mysql(-1);) 2025.06.13 15:43:00.875410 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_decrypt_mysql(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:00.876771 [ 8442 ] {4d6169e2-1971-4b0b-a0bc-62546922e0e4} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1078, line 1079) (in query: SELECT quantilesExactExclusive(NULL, NULL);) 2025.06.13 15:43:00.898781 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:01.036704 [ 5978 ] {db87549e-898a-4c78-a46d-3bb49c9aa1b7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_encrypt_mysql(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 166, line 167) (in query: SELECT aes_encrypt_mysql(-1);) 2025.06.13 15:43:01.039898 [ 8442 ] {22e6cab9-9923-44f4-a844-89ec44a0c9ab} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1079, line 1080) (in query: SELECT quantilesExactHigh(NULL, NULL);) 2025.06.13 15:43:01.045343 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:01.082499 [ 8431 ] {19b0ff96-bd46-4b4d-8edb-82064f51d7c8} executeQuery: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 358, line 359) (in query: SELECT corrStable();) 2025.06.13 15:43:01.092080 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:01.109359 [ 8442 ] {c2d22105-28a8-417a-ac7d-8159fe3e57b3} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1080, line 1081) (in query: SELECT quantilesExactInclusive(NULL, NULL);) 2025.06.13 15:43:01.118667 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_encrypt_mysql(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:01.120314 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:01.177191 [ 8431 ] {a7147ade-1512-47a6-a617-6f1f839eb008} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 0, should be 1: In scope SELECT cos(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 359, line 360) (in query: SELECT cos();) 2025.06.13 15:43:01.208234 [ 5978 ] {54920958-7c1c-48ba-9e31-afe15e23e5bb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'age'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT age(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 167, line 168) (in query: SELECT age(-1);) 2025.06.13 15:43:01.208482 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 0, should be 1: In scope SELECT cos(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:01.238950 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'age'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT age(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:01.239871 [ 8442 ] {6e858e38-62ea-49d7-8189-3655ffa15db4} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1081, line 1082) (in query: SELECT quantilesExactLow(NULL, NULL);) 2025.06.13 15:43:01.333482 [ 8431 ] {75a0c7a0-bd06-4874-b2d0-36448b816dd2} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 0, should be 1: In scope SELECT cosh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 360, line 361) (in query: SELECT cosh();) 2025.06.13 15:43:01.340686 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:01.356620 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 0, should be 1: In scope SELECT cosh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:01.488273 [ 8442 ] {496be442-db53-4318-b52c-af1343c6a010} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1082, line 1083) (in query: SELECT quantilesExactWeighted(NULL, NULL);) 2025.06.13 15:43:01.499331 [ 5978 ] {acd5041f-8977-4876-8c3e-a0c51ba3d4be} executeQuery: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 168, line 169) (in query: SELECT aggThrow(-1);) 2025.06.13 15:43:01.506722 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:01.513521 [ 5978 ] {} TCPHandler: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) 2025.06.13 15:43:01.538155 [ 8431 ] {27ed8990-f875-48d2-8a83-76345fe08787} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 0, should be 2: In scope SELECT cosineDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 361, line 362) (in query: SELECT cosineDistance();) 2025.06.13 15:43:01.658620 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 0, should be 2: In scope SELECT cosineDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:01.667433 [ 5978 ] {46751162-97fb-4238-8be2-145283fcc58f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'alphaTokens'. Expected: String, got: Int8: In scope SELECT alphaTokens(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 169, line 170) (in query: SELECT alphaTokens(-1);) 2025.06.13 15:43:01.673724 [ 8442 ] {6a515ee5-09e3-417a-8902-afda2bd4f55d} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1083, line 1084) (in query: SELECT quantilesExactWeightedInterpolated(NULL, NULL);) 2025.06.13 15:43:01.675357 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'alphaTokens'. Expected: String, got: Int8: In scope SELECT alphaTokens(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:01.708869 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:01.750543 [ 5978 ] {3187c785-087e-48f3-b154-0c4c03f0019f} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 170, line 171) (in query: SELECT analysisOfVariance(-1);) 2025.06.13 15:43:01.758175 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:01.785640 [ 8442 ] {595dcb78-e0e8-42fc-8c8d-4fb8ddee4e08} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1084, line 1085) (in query: SELECT quantilesGK(NULL, NULL);) 2025.06.13 15:43:01.802524 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:01.876639 [ 5978 ] {d7cf1035-ee64-46b7-bbc8-36609fe0dd74} executeQuery: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 1: In scope SELECT and(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 171, line 172) (in query: SELECT and(-1);) 2025.06.13 15:43:01.880605 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 1: In scope SELECT and(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:43:01.910209 [ 8431 ] {ee9258a4-82e1-4886-8891-0c16c75196e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 0, should be 1: In scope SELECT countDigits(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 363, line 364) (in query: SELECT countDigits();) 2025.06.13 15:43:01.914995 [ 8442 ] {a3ccaad9-848f-4cd4-a7cf-94716356e459} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1085, line 1086) (in query: SELECT quantilesInterpolatedWeighted(NULL, NULL);) 2025.06.13 15:43:01.917670 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 0, should be 1: In scope SELECT countDigits(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:01.923868 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:02.011542 [ 5978 ] {a6cade2e-e604-4ac6-bcbe-4bcd2e2b6fa0} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 172, line 173) (in query: SELECT anova(-1);) 2025.06.13 15:43:02.016684 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:02.024348 [ 8442 ] {ec497d84-b278-4e5c-877a-f65760c8e067} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1086, line 1087) (in query: SELECT quantilesTDigest(NULL, NULL);) 2025.06.13 15:43:02.024907 [ 8431 ] {aad113b8-9799-47c4-b05b-a5269eb21255} executeQuery: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 0, should be 2: In scope SELECT countEqual(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 364, line 365) (in query: SELECT countEqual();) 2025.06.13 15:43:02.031095 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:02.033602 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 0, should be 2: In scope SELECT countEqual(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:02.132917 [ 8442 ] {d43b2759-88c8-4251-8895-b57a588d754d} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1087, line 1088) (in query: SELECT quantilesTDigestWeighted(NULL, NULL);) 2025.06.13 15:43:02.136781 [ 8431 ] {6af0d7a8-35b5-476c-b247-fc7dfa38eea7} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 0, should be 2: In scope SELECT countMatches(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 365, line 366) (in query: SELECT countMatches();) 2025.06.13 15:43:02.142265 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:02.150536 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 0, should be 2: In scope SELECT countMatches(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:02.251625 [ 8431 ] {70c5b182-2432-45cc-8feb-dca30788151d} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT countMatchesCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 366, line 367) (in query: SELECT countMatchesCaseInsensitive();) 2025.06.13 15:43:02.261374 [ 18509 ] {f491ab83-f461-44b8-9629-53aa0443b523} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=874, jobs=841). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42626) (comment: 02366_kql_func_ip.sql) (query 98, line 105) (in query: print parse_ipv6_mask("::192.168.255.255/24", 128);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:43:02.262584 [ 8442 ] {3b35786e-ac30-4f74-896c-d54e2e7954fb} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1088, line 1089) (in query: SELECT quantilesTiming(NULL, NULL);) 2025.06.13 15:43:02.287837 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT countMatchesCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:02.295280 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:02.303983 [ 18509 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=874, jobs=841). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:43:02.396587 [ 8431 ] {ff297a1c-cf52-41b0-91d2-f0d3aa714ca6} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstrings doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstrings(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 367, line 368) (in query: SELECT countSubstrings();) 2025.06.13 15:43:02.431451 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstrings doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstrings(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:02.432488 [ 8442 ] {ae90a870-fc60-47c6-a098-44c8dbe704a2} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1089, line 1090) (in query: SELECT quantilesTimingWeighted(NULL, NULL);) 2025.06.13 15:43:02.457529 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:02.563681 [ 8442 ] {6b3f7248-6fe1-4642-9deb-38cb0e040607} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT queryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1090, line 1091) (in query: SELECT queryID(NULL, NULL);) 2025.06.13 15:43:02.571992 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT queryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:02.576759 [ 8431 ] {50546b2c-4062-4fae-8373-a5c44189dbcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 368, line 369) (in query: SELECT countSubstringsCaseInsensitive();) 2025.06.13 15:43:02.585634 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:02.651658 [ 8431 ] {b2b79fbb-17f0-46fc-8c0d-79a5accd9ac4} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitiveUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 369, line 370) (in query: SELECT countSubstringsCaseInsensitiveUTF8();) 2025.06.13 15:43:02.657853 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitiveUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:02.658773 [ 8442 ] {517fba94-aaf5-48e7-a8ed-cd0908f2661b} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 2, should be 1: In scope SELECT queryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1091, line 1092) (in query: SELECT queryString(NULL, NULL);) 2025.06.13 15:43:02.664071 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 2, should be 1: In scope SELECT queryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:02.727884 [ 8431 ] {45d389e7-e010-43ff-a952-93d07f6890d3} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 370, line 371) (in query: SELECT covarPop();) 2025.06.13 15:43:02.730989 [ 8442 ] {abdb7d74-35e8-4e2d-a55b-074d02c25712} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1092, line 1093) (in query: SELECT queryStringAndFragment(NULL, NULL);) 2025.06.13 15:43:02.739525 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:02.739604 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:02.831982 [ 8442 ] {40a5452d-00c5-42f0-8e95-535554cdb9ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1093, line 1094) (in query: SELECT query_id(NULL, NULL);) 2025.06.13 15:43:02.832293 [ 2860 ] {0c7bfe50-02ec-46c3-9e07-7c6f19b758f3} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58318) (comment: 02337_check_translate_qualified_names_matcher.sql) (query 1, line 1) (in query: CREATE TABLE nested_name_tuples ( `a` Tuple(x String, y Tuple(i Int32, j String)) ) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:02.846108 [ 2860 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:02.858708 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:02.956582 [ 8442 ] {4b398ed4-4bf9-405f-81aa-53aec6d940ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 2, should be 1: In scope SELECT radians(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1094, line 1095) (in query: SELECT radians(NULL, NULL);) 2025.06.13 15:43:03.056486 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 2, should be 1: In scope SELECT radians(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:03.142348 [ 8431 ] {ed84ddfe-6f31-427a-9c9a-0b152f51acd3} executeQuery: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 372, line 373) (in query: SELECT covarPopStable();) 2025.06.13 15:43:03.181666 [ 8442 ] {38a16b48-9517-49e2-9e23-d8061939e675} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1095, line 1096) (in query: SELECT rand(NULL, NULL);) 2025.06.13 15:43:03.191729 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:03.197849 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:03.260241 [ 8431 ] {484492a1-322d-47ed-a7a5-d8a5da652590} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 373, line 374) (in query: SELECT covarSamp();) 2025.06.13 15:43:03.287640 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:03.327195 [ 8442 ] {0ddc90d2-2c96-469e-8d10-869910e2929d} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1096, line 1097) (in query: SELECT rand32(NULL, NULL);) 2025.06.13 15:43:03.386444 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:03.558710 [ 8442 ] {c52fa0ac-58ec-4246-b70f-82c2fd89cce6} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1097, line 1098) (in query: SELECT rand64(NULL, NULL);) 2025.06.13 15:43:03.575250 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:03.672120 [ 8431 ] {a070170e-3c3d-4d75-af47-a8c2fe907067} executeQuery: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 375, line 376) (in query: SELECT covarSampStable();) 2025.06.13 15:43:03.678046 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:03.803139 [ 8431 ] {c3b81645-b35d-4d77-8f0e-b87b12023cca} executeQuery: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 376, line 377) (in query: SELECT cramersV();) 2025.06.13 15:43:03.827691 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:03.878272 [ 18511 ] {f36dcc97-a3c8-49ed-8220-38b122501854} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37380) (comment: 01780_column_sparse_materialize.sql) (query 2, line 3) (in query: CREATE TABLE sparse_t (`id` UInt64, `u` UInt64, `s` String, `arr1` Array(String), `arr2` Array(UInt64), `t` Tuple(a UInt64, s String)) ENGINE = MergeTree ORDER BY tuple() SETTINGS ratio_of_defaults_for_sparse_serialization = 0.1, index_granularity = 21315, min_bytes_for_wide_part = 0, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 372817400, compact_parts_max_bytes_to_buffer = 113676949, compact_parts_max_granules_to_buffer = 128, compact_parts_merge_max_bytes_to_prefetch_part = 6286873, merge_max_block_size = 4860, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 23643869, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 94781, primary_key_compress_block_size = 60330, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:03.911563 [ 8431 ] {f7370818-6d83-4b8a-a702-e524f5483d96} executeQuery: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 377, line 378) (in query: SELECT cramersVBiasCorrected();) 2025.06.13 15:43:03.921120 [ 8442 ] {2d428123-4190-4a2e-9a97-eda4d4f8fdc1} executeQuery: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 2, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1100, line 1101) (in query: SELECT randCanonical(NULL, NULL);) 2025.06.13 15:43:04.003904 [ 18511 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:04.004979 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:04.013111 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 2, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:04.061847 [ 5978 ] {c7c9404b-5ff3-4389-bba5-5bdf2d042c46} executeQuery: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 1, should be 2: In scope SELECT appendTrailingCharIfAbsent(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 183, line 184) (in query: SELECT appendTrailingCharIfAbsent(-1);) 2025.06.13 15:43:04.072996 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 1, should be 2: In scope SELECT appendTrailingCharIfAbsent(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:04.187444 [ 8442 ] {0a0987b4-d49c-40bc-98f2-22b334491b45} executeQuery: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 2, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1102, line 1103) (in query: SELECT randConstant(NULL, NULL);) 2025.06.13 15:43:04.210896 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 2, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:04.564143 [ 5978 ] {f3d2d801-270e-43d3-b54a-b3ab3d866914} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 186, line 187) (in query: SELECT approx_top_sum(-1);) 2025.06.13 15:43:04.572399 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:04.659053 [ 5978 ] {ca5ab198-86fe-4ff3-b322-7da72eec3ada} executeQuery: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 187, line 188) (in query: SELECT argMax(-1);) 2025.06.13 15:43:04.692655 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:04.733687 [ 8431 ] {8d213ac9-4903-484e-905b-0a1fcd8065bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 0, should be 1: In scope SELECT currentSchemas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 383, line 384) (in query: SELECT currentSchemas();) 2025.06.13 15:43:04.739308 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 0, should be 1: In scope SELECT currentSchemas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:04.744244 [ 5978 ] {cdacd483-5d9c-4afc-9901-6e7738960b2f} executeQuery: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 188, line 189) (in query: SELECT argMin(-1);) 2025.06.13 15:43:04.750711 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:05.033633 [ 5978 ] {04dd7f33-04c4-46c0-8a39-7ae07b3578bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 1, should be 2, 3 or 4: In scope SELECT arrayAUC(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 190, line 191) (in query: SELECT arrayAUC(-1);) 2025.06.13 15:43:05.052839 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 1, should be 2, 3 or 4: In scope SELECT arrayAUC(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:05.346949 [ 5978 ] {561c46e1-bce5-40d1-a3b0-76484556227c} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 1, should be 2 or 3: In scope SELECT arrayAUCPR(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 191, line 192) (in query: SELECT arrayAUCPR(-1);) 2025.06.13 15:43:05.357510 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 1, should be 2 or 3: In scope SELECT arrayAUCPR(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:05.518962 [ 5978 ] {d863084e-b099-4df9-a212-3224d6299885} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayAll must be array. Found Int8 instead: In scope SELECT arrayAll(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 192, line 193) (in query: SELECT arrayAll(-1);) 2025.06.13 15:43:05.591281 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayAll must be array. Found Int8 instead: In scope SELECT arrayAll(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:05.638431 [ 5978 ] {abde0806-17be-4c99-8be9-7ecf58bb8517} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayAvg must be array. Found Int8 instead: In scope SELECT arrayAvg(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 193, line 194) (in query: SELECT arrayAvg(-1);) 2025.06.13 15:43:05.645575 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayAvg must be array. Found Int8 instead: In scope SELECT arrayAvg(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:05.817003 [ 8431 ] {420c0790-67c6-426a-b879-8334cf848683} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 0, should be 1: In scope SELECT current_schemas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 388, line 389) (in query: SELECT current_schemas();) 2025.06.13 15:43:05.823213 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 0, should be 1: In scope SELECT current_schemas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:05.831462 [ 5978 ] {b6cf5f92-82bf-428f-92d3-3a3ef7c0c90c} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayCompact must be array. Found Int8 instead: In scope SELECT arrayCompact(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 194, line 195) (in query: SELECT arrayCompact(-1);) 2025.06.13 15:43:05.837417 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayCompact must be array. Found Int8 instead: In scope SELECT arrayCompact(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:05.912825 [ 8442 ] {84c8d2ad-af12-4954-a4bb-675c3b80d508} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 2, should be 1: In scope SELECT randomFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1111, line 1112) (in query: SELECT randomFixedString(NULL, NULL);) 2025.06.13 15:43:05.922754 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 2, should be 1: In scope SELECT randomFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:05.922609 [ 5978 ] {add9ee2b-8dae-4b28-8985-bb96f9a211f4} executeQuery: Code: 43. DB::Exception: Argument 0 for function arrayConcat must be an array but it has type Int8.: In scope SELECT arrayConcat(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 195, line 196) (in query: SELECT arrayConcat(-1);) 2025.06.13 15:43:06.014079 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function arrayConcat must be an array but it has type Int8.: In scope SELECT arrayConcat(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:06.094012 [ 5978 ] {d82a6e87-3432-49d6-8984-d7f5ab9cc1cc} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayCount must be array. Found Int8 instead: In scope SELECT arrayCount(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 196, line 197) (in query: SELECT arrayCount(-1);) 2025.06.13 15:43:06.099469 [ 8431 ] {95fb764e-79a4-4879-bb25-f0217b8396e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 0, should be 1: In scope SELECT cutFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 391, line 392) (in query: SELECT cutFragment();) 2025.06.13 15:43:06.115656 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayCount must be array. Found Int8 instead: In scope SELECT arrayCount(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:06.119940 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 0, should be 1: In scope SELECT cutFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:06.279535 [ 5978 ] {4324d9e2-cea2-49ef-9518-59e41d215eac} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayCumSum must be array. Found Int8 instead: In scope SELECT arrayCumSum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 197, line 198) (in query: SELECT arrayCumSum(-1);) 2025.06.13 15:43:06.281717 [ 8431 ] {91ee7c65-fc4a-4a36-9f66-d42f25ff2db0} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 0, should be 3: In scope SELECT cutIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 392, line 393) (in query: SELECT cutIPv6();) 2025.06.13 15:43:06.288574 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayCumSum must be array. Found Int8 instead: In scope SELECT arrayCumSum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:06.292222 [ 8442 ] {a6082068-822a-40b6-bdc9-1215201034b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 2, should be 1: In scope SELECT randomStringUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1114, line 1115) (in query: SELECT randomStringUTF8(NULL, NULL);) 2025.06.13 15:43:06.298805 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 0, should be 3: In scope SELECT cutIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:06.301454 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 2, should be 1: In scope SELECT randomStringUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:06.349234 [ 5978 ] {8d0cf7d5-7034-4314-a2c1-deefbb8308d7} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayCumSumNonNegative must be array. Found Int8 instead: In scope SELECT arrayCumSumNonNegative(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 198, line 199) (in query: SELECT arrayCumSumNonNegative(-1);) 2025.06.13 15:43:06.355747 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayCumSumNonNegative must be array. Found Int8 instead: In scope SELECT arrayCumSumNonNegative(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:06.357460 [ 8431 ] {3f8a7460-faac-44ae-a07e-f4177fdd8f9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 0, should be 1: In scope SELECT cutQueryString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 393, line 394) (in query: SELECT cutQueryString();) 2025.06.13 15:43:06.363100 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 0, should be 1: In scope SELECT cutQueryString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:06.394013 [ 5978 ] {74850744-120f-46c4-b592-71356440cec3} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayDifference must be array. Found Int8 instead: In scope SELECT arrayDifference(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 199, line 200) (in query: SELECT arrayDifference(-1);) 2025.06.13 15:43:06.398434 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayDifference must be array. Found Int8 instead: In scope SELECT arrayDifference(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:06.402309 [ 8431 ] {a51cadfb-be91-4bf1-8b3b-f11189636842} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 0, should be 1: In scope SELECT cutQueryStringAndFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 394, line 395) (in query: SELECT cutQueryStringAndFragment();) 2025.06.13 15:43:06.409107 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 0, should be 1: In scope SELECT cutQueryStringAndFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:06.493996 [ 5978 ] {e99497bd-075d-4c0e-8692-b91560691b79} executeQuery: Code: 43. DB::Exception: Argument for function arrayDistinct must be array but it has type Int8.: In scope SELECT arrayDistinct(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 200, line 201) (in query: SELECT arrayDistinct(-1);) 2025.06.13 15:43:06.501470 [ 8431 ] {0baf03c3-aade-4a22-b341-b38e535fbcd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 395, line 396) (in query: SELECT cutToFirstSignificantSubdomain();) 2025.06.13 15:43:06.505385 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function arrayDistinct must be array but it has type Int8.: In scope SELECT arrayDistinct(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:06.529955 [ 5978 ] {924f313c-ba62-4043-a1b9-c356e0ae228b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 1, should be 2: In scope SELECT arrayDotProduct(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 201, line 202) (in query: SELECT arrayDotProduct(-1);) 2025.06.13 15:43:06.535446 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 1, should be 2: In scope SELECT arrayDotProduct(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:06.561121 [ 5978 ] {6d4c739d-433f-4262-a254-5006bbf24548} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 1, should be 2: In scope SELECT arrayElement(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 202, line 203) (in query: SELECT arrayElement(-1);) 2025.06.13 15:43:06.564560 [ 8442 ] {3e7bad4f-7476-44c7-9988-657f77959f46} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1116, line 1117) (in query: SELECT rank(NULL, NULL);) 2025.06.13 15:43:06.569007 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 1, should be 2: In scope SELECT arrayElement(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:06.575123 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:43:06.588253 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:06.602752 [ 5978 ] {365dd6b0-18ee-468e-a1ee-847efeaaaf1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 1, should be 2: In scope SELECT arrayElementOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 203, line 204) (in query: SELECT arrayElementOrNull(-1);) 2025.06.13 15:43:06.609699 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 1, should be 2: In scope SELECT arrayElementOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:06.648057 [ 8431 ] {2956a8a7-5871-4075-9b30-7009fb561e9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 396, line 397) (in query: SELECT cutToFirstSignificantSubdomainCustom();) 2025.06.13 15:43:06.654286 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:06.684746 [ 5978 ] {5126f4ae-f46d-40b8-9033-b8ccdcf3935b} executeQuery: Code: 43. DB::Exception: First argument for function arrayEnumerate must be an array but it has type Int8.: In scope SELECT arrayEnumerate(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 204, line 205) (in query: SELECT arrayEnumerate(-1);) 2025.06.13 15:43:06.691813 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayEnumerate must be an array but it has type Int8.: In scope SELECT arrayEnumerate(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:06.793148 [ 8431 ] {4dda25e6-19d4-42b4-8e9f-907ca723e0b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 397, line 398) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC();) 2025.06.13 15:43:06.801575 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:06.876780 [ 5978 ] {ea76727c-e330-426c-ae41-e8c6abc68909} executeQuery: Code: 43. DB::Exception: All arguments for function arrayEnumerateDense must be arrays but argument 1 has type Int8.: In scope SELECT arrayEnumerateDense(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 205, line 206) (in query: SELECT arrayEnumerateDense(-1);) 2025.06.13 15:43:06.884084 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: All arguments for function arrayEnumerateDense must be arrays but argument 1 has type Int8.: In scope SELECT arrayEnumerateDense(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:06.901713 [ 3499 ] {} cedd941f-fc78-4860-b03e-a0333e6934d3::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000310af0f4 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000310ac839 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:06.902581 [ 3504 ] {} ef3010bc-8941-47d6-b6f7-4f5bd67d929c::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000310af0f4 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000310ac839 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:06.903917 [ 3499 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {cedd941f-fc78-4860-b03e-a0333e6934d3::all_0_0_0_1}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000310af0f4 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000310ac839 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:06.905396 [ 3504 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ef3010bc-8941-47d6-b6f7-4f5bd67d929c::all_0_0_0_1}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000310af0f4 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000310ac839 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:06.923718 [ 8431 ] {df4c7e48-4e33-40e0-8382-988c78d1287b} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 398, line 399) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW();) 2025.06.13 15:43:06.923826 [ 8442 ] {b799d24e-560f-4e22-ac56-6e09bfcd1fa5} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1118, line 1119) (in query: SELECT readWKTLineString(NULL, NULL);) 2025.06.13 15:43:06.937941 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:06.939925 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:06.961263 [ 5978 ] {114fddc3-cf5e-4db4-8d25-09e249531586} executeQuery: Code: 36. DB::Exception: First argument of arrayEnumerateDenseRanked must be a positive integer: In scope SELECT arrayEnumerateDenseRanked(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 206, line 207) (in query: SELECT arrayEnumerateDenseRanked(-1);) 2025.06.13 15:43:07.000288 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: First argument of arrayEnumerateDenseRanked must be a positive integer: In scope SELECT arrayEnumerateDenseRanked(-1). (BAD_ARGUMENTS) 2025.06.13 15:43:07.089414 [ 8442 ] {a470d642-87a7-40d8-a52c-9bb3d45ff453} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1119, line 1120) (in query: SELECT readWKTMultiLineString(NULL, NULL);) 2025.06.13 15:43:07.093263 [ 5978 ] {9ae74805-9364-42a7-8364-8d1ade2c7170} executeQuery: Code: 43. DB::Exception: All arguments for function arrayEnumerateUniq must be arrays but argument 1 has type Int8.: In scope SELECT arrayEnumerateUniq(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 207, line 208) (in query: SELECT arrayEnumerateUniq(-1);) 2025.06.13 15:43:07.094198 [ 8431 ] {8a6d82a7-ed66-4e97-8535-eee07b2deb28} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 399, line 400) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC();) 2025.06.13 15:43:07.101844 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:07.111204 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:07.111342 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: All arguments for function arrayEnumerateUniq must be arrays but argument 1 has type Int8.: In scope SELECT arrayEnumerateUniq(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:07.320302 [ 8431 ] {8833f6ae-1ea7-4d55-8d0d-89316494c92e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 400, line 401) (in query: SELECT cutToFirstSignificantSubdomainRFC();) 2025.06.13 15:43:07.320550 [ 5978 ] {a7e67a64-9804-41b4-89c5-67f887fe497f} executeQuery: Code: 36. DB::Exception: First argument of arrayEnumerateUniqRanked must be a positive integer: In scope SELECT arrayEnumerateUniqRanked(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 208, line 209) (in query: SELECT arrayEnumerateUniqRanked(-1);) 2025.06.13 15:43:07.320683 [ 8442 ] {c0b2ce29-04d3-4566-ab69-26c832528735} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1120, line 1121) (in query: SELECT readWKTMultiPolygon(NULL, NULL);) 2025.06.13 15:43:07.328722 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:07.337741 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: First argument of arrayEnumerateUniqRanked must be a positive integer: In scope SELECT arrayEnumerateUniqRanked(-1). (BAD_ARGUMENTS) 2025.06.13 15:43:07.337901 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:07.496695 [ 8431 ] {bf237614-5aee-4a8e-9dc6-de27d4d9d690} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 401, line 402) (in query: SELECT cutToFirstSignificantSubdomainWithWWW();) 2025.06.13 15:43:07.497058 [ 8442 ] {9048610a-5e83-4c9b-87e6-473db8f29bdf} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 2, should be 1: In scope SELECT readWKTPoint(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1121, line 1122) (in query: SELECT readWKTPoint(NULL, NULL);) 2025.06.13 15:43:07.497287 [ 5978 ] {172ae5fd-28c7-4def-8aac-46398ca93ce5} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayExists must be array. Found Int8 instead: In scope SELECT arrayExists(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 209, line 210) (in query: SELECT arrayExists(-1);) 2025.06.13 15:43:07.572524 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:07.574990 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 2, should be 1: In scope SELECT readWKTPoint(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:07.578817 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayExists must be array. Found Int8 instead: In scope SELECT arrayExists(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:07.681885 [ 8442 ] {18b83d6e-08d8-4a93-8013-2e9060f13c77} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1122, line 1123) (in query: SELECT readWKTPolygon(NULL, NULL);) 2025.06.13 15:43:07.683700 [ 8431 ] {b0f5a5cb-0e94-466c-9993-b3981d6c889f} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 402, line 403) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC();) 2025.06.13 15:43:07.689256 [ 5978 ] {298f4672-f984-4313-86bf-fd2607931d48} executeQuery: Code: 42. DB::Exception: Function arrayFill needs at least 2 arguments, passed 1: In scope SELECT arrayFill(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 210, line 211) (in query: SELECT arrayFill(-1);) 2025.06.13 15:43:07.689978 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:07.694093 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:07.702511 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFill needs at least 2 arguments, passed 1: In scope SELECT arrayFill(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:07.903108 [ 8431 ] {82105444-f407-42ed-ae62-f2fec0e1ef65} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 0, should be 2: In scope SELECT cutURLParameter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 403, line 404) (in query: SELECT cutURLParameter();) 2025.06.13 15:43:07.984771 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 0, should be 2: In scope SELECT cutURLParameter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:07.993591 [ 8442 ] {9e6effbb-edd8-40f9-9dcc-0ac3fa4112c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 2, should be 1: In scope SELECT readWKTRing(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1123, line 1124) (in query: SELECT readWKTRing(NULL, NULL);) 2025.06.13 15:43:07.999661 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 2, should be 1: In scope SELECT readWKTRing(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:08.052507 [ 5978 ] {db407db6-2187-4eca-bdc4-bd7d0a21b124} executeQuery: Code: 42. DB::Exception: Function arrayFilter needs at least 2 arguments, passed 1: In scope SELECT arrayFilter(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 211, line 212) (in query: SELECT arrayFilter(-1);) 2025.06.13 15:43:08.059100 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFilter needs at least 2 arguments, passed 1: In scope SELECT arrayFilter(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:08.082274 [ 8431 ] {7ac625c4-85ba-40f7-9970-99f74e97e524} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 0, should be 1: In scope SELECT cutWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 404, line 405) (in query: SELECT cutWWW();) 2025.06.13 15:43:08.094142 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 0, should be 1: In scope SELECT cutWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:08.157974 [ 5978 ] {34f5e184-cd04-4380-a413-886d3f6ae281} executeQuery: Code: 42. DB::Exception: Function arrayFirst needs at least 2 arguments, passed 1: In scope SELECT arrayFirst(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 212, line 213) (in query: SELECT arrayFirst(-1);) 2025.06.13 15:43:08.166381 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFirst needs at least 2 arguments, passed 1: In scope SELECT arrayFirst(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:08.169903 [ 8431 ] {51e151c4-12f1-4be2-a39e-d8e69f994fe8} executeQuery: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 0, should be 2: In scope SELECT damerauLevenshteinDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 405, line 406) (in query: SELECT damerauLevenshteinDistance();) 2025.06.13 15:43:08.178136 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 0, should be 2: In scope SELECT damerauLevenshteinDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:08.231364 [ 8442 ] {014c4dfa-dfa0-4bba-bd28-4f8670118e3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 2, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1125, line 1126) (in query: SELECT regexpQuoteMeta(NULL, NULL);) 2025.06.13 15:43:08.241078 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 2, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:08.291434 [ 8431 ] {fd8dd6a5-5854-4c24-90c9-aeaf6a0738f3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 406, line 407) (in query: SELECT dateDiff();) 2025.06.13 15:43:08.304604 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:08.364424 [ 5978 ] {7b21f1e5-45e3-44c3-b8e2-08064eaf20e9} executeQuery: Code: 42. DB::Exception: Function arrayFirstIndex needs at least 2 arguments, passed 1: In scope SELECT arrayFirstIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 213, line 214) (in query: SELECT arrayFirstIndex(-1);) 2025.06.13 15:43:08.370998 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFirstIndex needs at least 2 arguments, passed 1: In scope SELECT arrayFirstIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:08.404340 [ 8431 ] {c4fc7768-128f-43b8-b95b-e9fe9b659d58} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateName doesn't match: passed 0: In scope SELECT dateName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 407, line 408) (in query: SELECT dateName();) 2025.06.13 15:43:08.413864 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateName doesn't match: passed 0: In scope SELECT dateName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:08.436883 [ 5978 ] {1de05ff0-a228-48ec-96b0-272a7669014d} executeQuery: Code: 42. DB::Exception: Function arrayFirstOrNull needs at least 2 arguments, passed 1: In scope SELECT arrayFirstOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 214, line 215) (in query: SELECT arrayFirstOrNull(-1);) 2025.06.13 15:43:08.451878 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayFirstOrNull needs at least 2 arguments, passed 1: In scope SELECT arrayFirstOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:08.488931 [ 8431 ] {801154d0-b95b-45f7-8a17-c3fdd6cc39d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTime64ToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 408, line 409) (in query: SELECT dateTime64ToSnowflake();) 2025.06.13 15:43:08.496251 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTime64ToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:08.579213 [ 5978 ] {aa998eec-345b-47c0-b75b-6148da5d5bd9} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function arrayFlatten, expected Array: In scope SELECT arrayFlatten(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 215, line 216) (in query: SELECT arrayFlatten(-1);) 2025.06.13 15:43:08.586995 [ 8431 ] {d9362df7-5daa-481d-abb9-125acf25e11a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTime64ToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 409, line 410) (in query: SELECT dateTime64ToSnowflakeID();) 2025.06.13 15:43:08.588572 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function arrayFlatten, expected Array: In scope SELECT arrayFlatten(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:08.608321 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTime64ToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:08.659378 [ 5978 ] {b33fc2da-c478-4185-88da-d02c1c83fbf5} executeQuery: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 216, line 217) (in query: SELECT arrayFold(-1);) 2025.06.13 15:43:08.669993 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:43:08.732371 [ 8431 ] {6d9c1211-5a64-4dc6-9d62-e4f56fc6d59c} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTimeToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 410, line 411) (in query: SELECT dateTimeToSnowflake();) 2025.06.13 15:43:08.745160 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTimeToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:08.764089 [ 5978 ] {2f71d2d1-5f66-4da3-bf35-69ec66fc5483} executeQuery: Code: 43. DB::Exception: Argument 0 for function arrayIntersect must be an array but it has type Int8.: In scope SELECT arrayIntersect(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 217, line 218) (in query: SELECT arrayIntersect(-1);) 2025.06.13 15:43:08.783455 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function arrayIntersect must be an array but it has type Int8.: In scope SELECT arrayIntersect(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:08.892987 [ 5978 ] {9e73233d-6d16-4d16-acec-4e5671995876} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 1, should be 2: In scope SELECT arrayJaccardIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 218, line 219) (in query: SELECT arrayJaccardIndex(-1);) 2025.06.13 15:43:08.918253 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 1, should be 2: In scope SELECT arrayJaccardIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:08.936475 [ 8431 ] {da094012-d52c-48c7-bc50-1cb6d44bb6b9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTimeToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 411, line 412) (in query: SELECT dateTimeToSnowflakeID();) 2025.06.13 15:43:08.946999 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTimeToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:09.106969 [ 5978 ] {0602ecf0-7c21-4f7f-b074-376b3b31a23b} executeQuery: Code: 43. DB::Exception: Argument for function arrayJoin must be Array or Map: In scope SELECT arrayJoin(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 219, line 220) (in query: SELECT arrayJoin(-1);) 2025.06.13 15:43:09.115375 [ 8431 ] {3c1b32be-8f0d-4250-b463-6c53039144fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 0, should be 2 or 3: In scope SELECT dateTrunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 412, line 413) (in query: SELECT dateTrunc();) 2025.06.13 15:43:09.120194 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function arrayJoin must be Array or Map: In scope SELECT arrayJoin(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:09.132291 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 0, should be 2 or 3: In scope SELECT dateTrunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:09.267938 [ 8431 ] {aadb933b-b8fe-418f-80ed-23e6d5ffe384} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 0, must be 2, 3 or 4: In scope SELECT date_bin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 413, line 414) (in query: SELECT date_bin();) 2025.06.13 15:43:09.284436 [ 5978 ] {c4c2f83f-0d07-4de1-9096-840b70852464} executeQuery: Code: 42. DB::Exception: Function arrayLast needs at least 2 arguments, passed 1: In scope SELECT arrayLast(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 220, line 221) (in query: SELECT arrayLast(-1);) 2025.06.13 15:43:09.364330 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 0, must be 2, 3 or 4: In scope SELECT date_bin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:09.365576 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayLast needs at least 2 arguments, passed 1: In scope SELECT arrayLast(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:09.448264 [ 8431 ] {a784ecd0-e256-4951-b3f4-5a533bf4f660} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 414, line 415) (in query: SELECT date_diff();) 2025.06.13 15:43:09.455231 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:09.506743 [ 5978 ] {8e3ce748-c34b-4a79-af98-36884e2b0489} executeQuery: Code: 42. DB::Exception: Function arrayLastIndex needs at least 2 arguments, passed 1: In scope SELECT arrayLastIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 221, line 222) (in query: SELECT arrayLastIndex(-1);) 2025.06.13 15:43:09.524612 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayLastIndex needs at least 2 arguments, passed 1: In scope SELECT arrayLastIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:09.539357 [ 8431 ] {e5add1a6-7a27-4c6b-9e5f-14633c834ee1} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeHTMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 415, line 416) (in query: SELECT decodeHTMLComponent();) 2025.06.13 15:43:09.548602 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeHTMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:09.554382 [ 8430 ] {c471588f-7a43-4595-bd62-088bf7101c83} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37452) (comment: 03040_dynamic_type_alters_1_wide_merge_tree.sql) (query 5, line 6) (in query: CREATE TABLE test (`x` UInt64, `y` UInt64) ENGINE = MergeTree ORDER BY x SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity = 53928, 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 = 10090278, compact_parts_max_granules_to_buffer = 14, compact_parts_merge_max_bytes_to_prefetch_part = 14630608, merge_max_block_size = 11983, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 991738, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 4228075929, index_granularity_bytes = 8322964, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 50, 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 = 18508, primary_key_compress_block_size = 26812, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:09.574381 [ 8430 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:09.643684 [ 5978 ] {619577ea-f0f7-4581-86d2-dd93050bda69} executeQuery: Code: 42. DB::Exception: Function arrayLastOrNull needs at least 2 arguments, passed 1: In scope SELECT arrayLastOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 222, line 223) (in query: SELECT arrayLastOrNull(-1);) 2025.06.13 15:43:09.653292 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayLastOrNull needs at least 2 arguments, passed 1: In scope SELECT arrayLastOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:09.654752 [ 8431 ] {6a7570e4-e1a0-432b-93f5-73051c77a761} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeURLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 416, line 417) (in query: SELECT decodeURLComponent();) 2025.06.13 15:43:09.668143 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeURLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:09.764079 [ 8431 ] {d1f76a13-fd31-4649-b0eb-701cb49b7c9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 0, should be 1: In scope SELECT decodeURLFormComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 417, line 418) (in query: SELECT decodeURLFormComponent();) 2025.06.13 15:43:09.775658 [ 5978 ] {8378446b-25e2-4764-9acd-d7eae55156d4} executeQuery: Code: 42. DB::Exception: Function arrayMap needs at least 2 arguments, passed 1: In scope SELECT arrayMap(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 223, line 224) (in query: SELECT arrayMap(-1);) 2025.06.13 15:43:09.862738 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 0, should be 1: In scope SELECT decodeURLFormComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:09.867611 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayMap needs at least 2 arguments, passed 1: In scope SELECT arrayMap(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:09.929142 [ 8431 ] {a599c127-54ea-44d7-bc21-3b820a851b27} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeXMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 418, line 419) (in query: SELECT decodeXMLComponent();) 2025.06.13 15:43:09.937870 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeXMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:09.938910 [ 5978 ] {b565f925-8178-417a-ba77-fca8e8580b68} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayMax must be array. Found Int8 instead: In scope SELECT arrayMax(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 224, line 225) (in query: SELECT arrayMax(-1);) 2025.06.13 15:43:09.967605 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayMax must be array. Found Int8 instead: In scope SELECT arrayMax(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:10.023453 [ 8431 ] {44f9ef5e-bfc4-46ef-b548-257380af97ae} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT decrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 419, line 420) (in query: SELECT decrypt();) 2025.06.13 15:43:10.033580 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT decrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:10.050838 [ 5978 ] {d2c03e66-8a23-4e51-ab17-dd5fe83ec683} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayMin must be array. Found Int8 instead: In scope SELECT arrayMin(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 225, line 226) (in query: SELECT arrayMin(-1);) 2025.06.13 15:43:10.069400 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayMin must be array. Found Int8 instead: In scope SELECT arrayMin(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:10.202535 [ 5978 ] {4133fd37-a554-45c0-9a12-11c223b0419f} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 1, should be 2: In scope SELECT arrayNormalizedGini(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 226, line 227) (in query: SELECT arrayNormalizedGini(-1);) 2025.06.13 15:43:10.220135 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 1, should be 2: In scope SELECT arrayNormalizedGini(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:10.416150 [ 5978 ] {fcdf5e10-1dc1-42aa-ae99-444703f47ea8} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 1, should be 2 or 3: In scope SELECT arrayPRAUC(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 227, line 228) (in query: SELECT arrayPRAUC(-1);) 2025.06.13 15:43:10.426851 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 1, should be 2 or 3: In scope SELECT arrayPRAUC(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:10.528774 [ 8442 ] {e5a89c3d-3f2d-4dbc-a165-669c892d8ddb} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1137, line 1138) (in query: SELECT reinterpretAsDate(NULL, NULL);) 2025.06.13 15:43:10.547324 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:10.565068 [ 8431 ] {d61c5f61-0df5-470a-80a7-62b6833ca3e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 0, should be 1: In scope SELECT defaultValueOfArgumentType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 422, line 423) (in query: SELECT defaultValueOfArgumentType();) 2025.06.13 15:43:10.586355 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 0, should be 1: In scope SELECT defaultValueOfArgumentType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:10.638936 [ 8430 ] {043e8cb2-8462-4dec-9d71-d99dd3246af0} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37464) (comment: 02918_wrong_dictionary_source.sql) (query 3, line 4) (in query: CREATE TABLE source_table (`id` UInt64, `value` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 11652, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 115, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 361562455, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 5981663, merge_max_block_size = 227, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 251306, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 19717782, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 87866, primary_key_compress_block_size = 59566, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:10.644097 [ 5978 ] {5150fb2e-7d80-40a7-98f7-cd6b0625d591} executeQuery: Code: 42. DB::Exception: Function arrayPartialReverseSort needs at least 2 arguments, passed 1: In scope SELECT arrayPartialReverseSort(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 228, line 229) (in query: SELECT arrayPartialReverseSort(-1);) 2025.06.13 15:43:10.657468 [ 8430 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:10.662170 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayPartialReverseSort needs at least 2 arguments, passed 1: In scope SELECT arrayPartialReverseSort(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:10.694855 [ 8442 ] {7d4f239a-61ce-43ce-b302-2b5c5b19f8dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1138, line 1139) (in query: SELECT reinterpretAsDateTime(NULL, NULL);) 2025.06.13 15:43:10.707924 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:10.714493 [ 8431 ] {916e5923-2e7f-46a6-80ad-47ec96e1f582} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 0, should be 1: In scope SELECT defaultValueOfTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 423, line 424) (in query: SELECT defaultValueOfTypeName();) 2025.06.13 15:43:10.721199 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 0, should be 1: In scope SELECT defaultValueOfTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:10.859153 [ 5978 ] {ce4ff09f-1198-4162-a42a-1ba91ddb0816} executeQuery: Code: 43. DB::Exception: First argument of function 'arrayPartialShuffle' must be array: In scope SELECT arrayPartialShuffle(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 229, line 230) (in query: SELECT arrayPartialShuffle(-1);) 2025.06.13 15:43:10.872040 [ 8442 ] {55dbf9f9-6564-4d53-a81b-c492e7c14944} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1139, line 1140) (in query: SELECT reinterpretAsFixedString(NULL, NULL);) 2025.06.13 15:43:10.872130 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function 'arrayPartialShuffle' must be array: In scope SELECT arrayPartialShuffle(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:10.889900 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:10.893661 [ 8431 ] {c716c7b7-c157-40fd-948c-01b26395a555} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 0, should be 1: In scope SELECT degrees(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 424, line 425) (in query: SELECT degrees();) 2025.06.13 15:43:10.963161 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 0, should be 1: In scope SELECT degrees(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:11.030943 [ 5978 ] {4b935b30-5ce2-4297-8495-34dd6c2d958d} executeQuery: Code: 42. DB::Exception: Function arrayPartialSort needs at least 2 arguments, passed 1: In scope SELECT arrayPartialSort(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 230, line 231) (in query: SELECT arrayPartialSort(-1);) 2025.06.13 15:43:11.041386 [ 8442 ] {3bb0b38e-8f13-4e9c-a107-3f6734960929} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1140, line 1141) (in query: SELECT reinterpretAsFloat32(NULL, NULL);) 2025.06.13 15:43:11.056572 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayPartialSort needs at least 2 arguments, passed 1: In scope SELECT arrayPartialSort(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:11.070790 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:11.076069 [ 8431 ] {84696829-3eb8-4318-8253-e0c8fa0ebc99} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 425, line 426) (in query: SELECT deltaSum();) 2025.06.13 15:43:11.095216 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:11.185200 [ 5978 ] {c162a986-9823-4001-9a3d-28ca225a02c1} executeQuery: Code: 43. DB::Exception: First argument for function arrayPopBack must be an array but it has type Int8.: In scope SELECT arrayPopBack(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 231, line 232) (in query: SELECT arrayPopBack(-1);) 2025.06.13 15:43:11.185702 [ 8431 ] {f83d355e-15c1-48d8-8e9e-4267d98d31ce} executeQuery: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 426, line 427) (in query: SELECT deltaSumTimestamp();) 2025.06.13 15:43:11.195237 [ 8442 ] {a5595fb7-7761-4d55-98fd-58dcedc2501a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1141, line 1142) (in query: SELECT reinterpretAsFloat64(NULL, NULL);) 2025.06.13 15:43:11.205517 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:11.207944 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayPopBack must be an array but it has type Int8.: In scope SELECT arrayPopBack(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:11.208168 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:11.347371 [ 8431 ] {632b814c-cedd-4282-92d1-ea59835fb2bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 0, should be 1: In scope SELECT demangle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 427, line 428) (in query: SELECT demangle();) 2025.06.13 15:43:11.349606 [ 8442 ] {35dc6857-c5cc-429b-b5c6-a8165b97d504} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1142, line 1143) (in query: SELECT reinterpretAsInt128(NULL, NULL);) 2025.06.13 15:43:11.366765 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:11.366992 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 0, should be 1: In scope SELECT demangle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:11.368952 [ 5978 ] {9e8cd85f-0b62-4d9e-9c7f-fd2e2f31dc1b} executeQuery: Code: 43. DB::Exception: First argument for function arrayPopFront must be an array but it has type Int8.: In scope SELECT arrayPopFront(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 232, line 233) (in query: SELECT arrayPopFront(-1);) 2025.06.13 15:43:11.412493 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayPopFront must be an array but it has type Int8.: In scope SELECT arrayPopFront(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:11.553415 [ 8442 ] {6b78c4eb-d326-4b17-b887-d1c9c37ac08a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1143, line 1144) (in query: SELECT reinterpretAsInt16(NULL, NULL);) 2025.06.13 15:43:11.557235 [ 5978 ] {78cdd2eb-84f0-421a-8ee8-f3dc11f9ed46} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayProduct must be array. Found Int8 instead: In scope SELECT arrayProduct(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 233, line 234) (in query: SELECT arrayProduct(-1);) 2025.06.13 15:43:11.565187 [ 8431 ] {cd7a66ff-4cb2-43e9-bab5-a7ba03d3b8b7} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 428, line 429) (in query: SELECT denseRank();) 2025.06.13 15:43:11.565577 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:11.575401 [ 8431 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:43:11.590640 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayProduct must be array. Found Int8 instead: In scope SELECT arrayProduct(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:11.700053 [ 8442 ] {632adb93-6b1d-4dc0-afd0-cd74c15e528a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1144, line 1145) (in query: SELECT reinterpretAsInt256(NULL, NULL);) 2025.06.13 15:43:11.802842 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:11.808106 [ 5978 ] {49fe69d3-9b03-46b6-95c8-1cf5f2d5ec97} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 1, should be 2: In scope SELECT arrayPushBack(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 234, line 235) (in query: SELECT arrayPushBack(-1);) 2025.06.13 15:43:11.813681 [ 8431 ] {7f6b4d64-ec52-4a1f-958d-1089c31a9869} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 429, line 430) (in query: SELECT dense_rank();) 2025.06.13 15:43:11.842665 [ 8431 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:43:11.844209 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 1, should be 2: In scope SELECT arrayPushBack(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:11.920246 [ 8442 ] {226d476a-d601-479f-97f2-d4921eb45bd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1145, line 1146) (in query: SELECT reinterpretAsInt32(NULL, NULL);) 2025.06.13 15:43:11.927636 [ 8431 ] {0ef9952f-0696-4286-bd21-cb2e0a03ffc3} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 430, line 431) (in query: SELECT detectCharset();) 2025.06.13 15:43:11.956830 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:11.965984 [ 8431 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:43:12.021756 [ 5978 ] {a37a3999-b9cd-43d3-ab0b-533da1e94d36} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 1, should be 2: In scope SELECT arrayPushFront(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 235, line 236) (in query: SELECT arrayPushFront(-1);) 2025.06.13 15:43:12.037322 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 1, should be 2: In scope SELECT arrayPushFront(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:12.093170 [ 8442 ] {2fc960eb-672c-4562-9ea7-d16e2240ac37} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1146, line 1147) (in query: SELECT reinterpretAsInt64(NULL, NULL);) 2025.06.13 15:43:12.109798 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:12.120799 [ 5978 ] {ff9f480c-5fe8-41b7-8cd7-aa191d9fdde1} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 1, should be 2, 3 or 4: In scope SELECT arrayROCAUC(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 236, line 237) (in query: SELECT arrayROCAUC(-1);) 2025.06.13 15:43:12.141730 [ 8431 ] {216ebabe-1148-4839-890c-862e3831f139} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 431, line 432) (in query: SELECT detectLanguage();) 2025.06.13 15:43:12.148629 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 1, should be 2, 3 or 4: In scope SELECT arrayROCAUC(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:12.160113 [ 8431 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:43:12.192815 [ 8442 ] {8f3bd32b-56de-434f-8a38-58ad38fe4d01} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1147, line 1148) (in query: SELECT reinterpretAsInt8(NULL, NULL);) 2025.06.13 15:43:12.213482 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:12.247117 [ 8431 ] {afc7e270-7c53-4733-bcad-35c3d1b65714} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 432, line 433) (in query: SELECT detectLanguageMixed();) 2025.06.13 15:43:12.261085 [ 8431 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:43:12.300771 [ 5978 ] {3abaa776-db32-4e6c-ae20-93bfca3cc4cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 1, should be 2: In scope SELECT arrayRandomSample(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 237, line 238) (in query: SELECT arrayRandomSample(-1);) 2025.06.13 15:43:12.310223 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 1, should be 2: In scope SELECT arrayRandomSample(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:12.340825 [ 8442 ] {9a19a34a-9278-4ddf-b468-7985229970ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1148, line 1149) (in query: SELECT reinterpretAsString(NULL, NULL);) 2025.06.13 15:43:12.346337 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:12.356158 [ 8431 ] {bb659e06-74a6-4894-b6ce-d60b6e86b889} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 433, line 434) (in query: SELECT detectLanguageUnknown();) 2025.06.13 15:43:12.372173 [ 8431 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:43:12.423282 [ 5978 ] {27155697-de53-4ef9-ba11-0412fc1d096a} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayReduce doesn't match: passed 1, should be at least 2.: In scope SELECT arrayReduce(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 238, line 239) (in query: SELECT arrayReduce(-1);) 2025.06.13 15:43:12.432674 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayReduce doesn't match: passed 1, should be at least 2.: In scope SELECT arrayReduce(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:43:12.451897 [ 8442 ] {abebad3c-5886-47f7-a66e-996c90d50755} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1149, line 1150) (in query: SELECT reinterpretAsUInt128(NULL, NULL);) 2025.06.13 15:43:12.460644 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:12.565369 [ 8431 ] {434c7da4-af51-4026-82f1-6975d34c2a60} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 434, line 435) (in query: SELECT detectProgrammingLanguage();) 2025.06.13 15:43:12.567958 [ 8442 ] {e9c1554f-8a73-4c04-8258-d0f6b295d656} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1150, line 1151) (in query: SELECT reinterpretAsUInt16(NULL, NULL);) 2025.06.13 15:43:12.570558 [ 5978 ] {7e92115c-7883-4c68-be58-eb91c0ee9de0} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReduceInRanges doesn't match: passed 1, should be at least 3.: In scope SELECT arrayReduceInRanges(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 239, line 240) (in query: SELECT arrayReduceInRanges(-1);) 2025.06.13 15:43:12.584813 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:12.588101 [ 8431 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:43:12.591360 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReduceInRanges doesn't match: passed 1, should be at least 3.: In scope SELECT arrayReduceInRanges(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:12.685869 [ 8442 ] {6ac9840e-e7ce-4f27-a705-d61418238706} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1151, line 1152) (in query: SELECT reinterpretAsUInt256(NULL, NULL);) 2025.06.13 15:43:12.686896 [ 8431 ] {352b60e8-1c97-4417-bc35-0d40b1e4d49c} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 435, line 436) (in query: SELECT detectTonality();) 2025.06.13 15:43:12.689257 [ 5978 ] {0fb141be-9769-4a73-a840-1650d1041ef7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayResize'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT arrayResize(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 240, line 241) (in query: SELECT arrayResize(-1);) 2025.06.13 15:43:12.697222 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:12.703682 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayResize'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT arrayResize(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:12.812821 [ 8431 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:43:12.827382 [ 8442 ] {f77454fc-5535-40ef-b152-c6913c7d0ac8} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1152, line 1153) (in query: SELECT reinterpretAsUInt32(NULL, NULL);) 2025.06.13 15:43:12.841148 [ 5978 ] {db98657c-1269-4324-8a1f-ce4b7f5f298a} executeQuery: Code: 43. DB::Exception: Argument for function arrayReverse must be array.: In scope SELECT arrayReverse(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 241, line 242) (in query: SELECT arrayReverse(-1);) 2025.06.13 15:43:12.853608 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:12.860135 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function arrayReverse must be array.: In scope SELECT arrayReverse(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:12.873915 [ 8431 ] {0d06610b-6eba-4f55-8b0e-df25672a5979} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 436, line 437) (in query: SELECT dictGet();) 2025.06.13 15:43:12.892486 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:12.945270 [ 8442 ] {0efcbd2e-aee5-4be5-a88b-e1bd075caaa8} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1153, line 1154) (in query: SELECT reinterpretAsUInt64(NULL, NULL);) 2025.06.13 15:43:12.952103 [ 5978 ] {cc5a54b7-9f65-4b58-8b06-7e58b2df7b87} executeQuery: Code: 42. DB::Exception: Function arrayReverseFill needs at least 2 arguments, passed 1: In scope SELECT arrayReverseFill(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 242, line 243) (in query: SELECT arrayReverseFill(-1);) 2025.06.13 15:43:12.959393 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:12.961904 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayReverseFill needs at least 2 arguments, passed 1: In scope SELECT arrayReverseFill(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.037960 [ 8442 ] {eeee2c20-99b6-4abf-998c-e95a821afe52} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1154, line 1155) (in query: SELECT reinterpretAsUInt8(NULL, NULL);) 2025.06.13 15:43:13.044608 [ 8431 ] {43ab206f-c773-4588-a609-dea3e68c61f8} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 437, line 438) (in query: SELECT dictGetAll();) 2025.06.13 15:43:13.057891 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.060477 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.065210 [ 5978 ] {5440c9d7-1f21-438a-bf8c-0b58b0d039f0} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arrayReverseSort must be array. Found Int8 instead: In scope SELECT arrayReverseSort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 243, line 244) (in query: SELECT arrayReverseSort(-1);) 2025.06.13 15:43:13.072881 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arrayReverseSort must be array. Found Int8 instead: In scope SELECT arrayReverseSort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:13.154742 [ 8442 ] {ee7c0528-f41b-48a4-8102-9771981b351d} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1155, line 1156) (in query: SELECT reinterpretAsUUID(NULL, NULL);) 2025.06.13 15:43:13.162361 [ 8431 ] {ecd53971-86d9-43f2-aa6b-c636e5804934} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 0, should be 2: In scope SELECT dictGetChildren(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 438, line 439) (in query: SELECT dictGetChildren();) 2025.06.13 15:43:13.165917 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.168823 [ 5978 ] {a977c85c-7454-415f-8fbb-c629e30fc1c2} executeQuery: Code: 42. DB::Exception: Function arrayReverseSplit needs at least 2 arguments, passed 1: In scope SELECT arrayReverseSplit(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 244, line 245) (in query: SELECT arrayReverseSplit(-1);) 2025.06.13 15:43:13.192338 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayReverseSplit needs at least 2 arguments, passed 1: In scope SELECT arrayReverseSplit(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.200687 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 0, should be 2: In scope SELECT dictGetChildren(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.318670 [ 8431 ] {b0952e8a-6c34-4223-a171-a556c046f55d} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 439, line 440) (in query: SELECT dictGetDate();) 2025.06.13 15:43:13.347654 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.383877 [ 8430 ] {f2b5e918-5f62-4d73-b6eb-8903f1800c6c} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60274) (comment: 01258_bom_tsv.sh) (in query: CREATE TABLE bom (a UInt8, b UInt8, c UInt8) ENGINE = Memory ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:43:13.394453 [ 8430 ] {f2b5e918-5f62-4d73-b6eb-8903f1800c6c} DynamicQueryHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:13.501197 [ 5978 ] {514dc586-d579-4b3e-9d6a-edb219392166} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 1, should be 2: In scope SELECT arrayRotateLeft(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 245, line 246) (in query: SELECT arrayRotateLeft(-1);) 2025.06.13 15:43:13.513789 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 1, should be 2: In scope SELECT arrayRotateLeft(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.517003 [ 8442 ] {b092f884-6474-4846-a670-c20b35f040fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1157, line 1158) (in query: SELECT replace(NULL, NULL);) 2025.06.13 15:43:13.523594 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.525480 [ 8431 ] {eb352088-0225-47e3-bc06-09032bbe4008} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetDateOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 440, line 441) (in query: SELECT dictGetDateOrDefault();) 2025.06.13 15:43:13.536260 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetDateOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.639742 [ 5978 ] {ddb315aa-ac1c-4232-bc3f-d34e4410bbc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 1, should be 2: In scope SELECT arrayRotateRight(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 246, line 247) (in query: SELECT arrayRotateRight(-1);) 2025.06.13 15:43:13.640439 [ 8442 ] {12186d4d-09af-433d-a8d3-5e39341932ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replaceAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1158, line 1159) (in query: SELECT replaceAll(NULL, NULL);) 2025.06.13 15:43:13.643579 [ 8431 ] {5d06307b-86e4-41ae-a328-00d723361128} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 441, line 442) (in query: SELECT dictGetDateTime();) 2025.06.13 15:43:13.651933 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replaceAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.652283 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 1, should be 2: In scope SELECT arrayRotateRight(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.658665 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.750968 [ 3894 ] {bb9d583b-2c6c-4ace-b776-d2bcd95af78b} executeQuery: Code: 60. DB::Exception: Table test_11.bom does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60280) (comment: 01258_bom_tsv.sh) (in query: INSERT INTO bom FORMAT TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:43:13.759234 [ 3894 ] {bb9d583b-2c6c-4ace-b776-d2bcd95af78b} DynamicQueryHandler: Code: 60. DB::Exception: Table test_11.bom does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:13.765764 [ 5978 ] {708f3d9c-3c12-49a3-a6d0-7c01ad22d9b9} executeQuery: Code: 42. DB::Exception: Function arrayShiftLeft requires at least two arguments.: In scope SELECT arrayShiftLeft(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 247, line 248) (in query: SELECT arrayShiftLeft(-1);) 2025.06.13 15:43:13.775395 [ 8442 ] {cf3ad583-b9ef-4b39-aecc-6ca14316adb3} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 2, should be 3: In scope SELECT replaceOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1159, line 1160) (in query: SELECT replaceOne(NULL, NULL);) 2025.06.13 15:43:13.785877 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayShiftLeft requires at least two arguments.: In scope SELECT arrayShiftLeft(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.791779 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 2, should be 3: In scope SELECT replaceOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.818955 [ 8431 ] {a3112b49-5890-4f04-ac5f-64f16ff51fa7} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetDateTimeOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 442, line 443) (in query: SELECT dictGetDateTimeOrDefault();) 2025.06.13 15:43:13.832449 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetDateTimeOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.891806 [ 5978 ] {cd5182d2-f5b7-4a08-8110-9bdfe135dd16} executeQuery: Code: 42. DB::Exception: Function arrayShiftRight requires at least two arguments.: In scope SELECT arrayShiftRight(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 248, line 249) (in query: SELECT arrayShiftRight(-1);) 2025.06.13 15:43:13.906987 [ 8442 ] {480d61a2-c625-4d22-848c-b5db1e08d200} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1160, line 1161) (in query: SELECT replaceRegexpAll(NULL, NULL);) 2025.06.13 15:43:13.916106 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.923069 [ 8431 ] {123e772c-4bb6-4481-be7d-4d6bb3f27ad6} executeQuery: Code: 42. DB::Exception: Illegal arguments size of function dictGetDescendants. Expects 2 or 3 arguments size. Actual size 0: In scope SELECT dictGetDescendants(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 443, line 444) (in query: SELECT dictGetDescendants();) 2025.06.13 15:43:13.933808 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arrayShiftRight requires at least two arguments.: In scope SELECT arrayShiftRight(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.968734 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Illegal arguments size of function dictGetDescendants. Expects 2 or 3 arguments size. Actual size 0: In scope SELECT dictGetDescendants(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:13.999732 [ 2860 ] {caa74693-6f1a-45d5-aed8-f9ee29cc9251} executeQuery: Code: 60. DB::Exception: Table test_11.bom does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60288) (comment: 01258_bom_tsv.sh) (in query: INSERT INTO bom FORMAT TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:43:14.012542 [ 2860 ] {caa74693-6f1a-45d5-aed8-f9ee29cc9251} DynamicQueryHandler: Code: 60. DB::Exception: Table test_11.bom does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:14.023852 [ 8442 ] {7ec41242-f3d1-466a-87d8-f523122a1b99} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1161, line 1162) (in query: SELECT replaceRegexpOne(NULL, NULL);) 2025.06.13 15:43:14.039265 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:14.043586 [ 5978 ] {6fee01bf-1741-47a7-9797-4fc24467aea1} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 1, should be 2: In scope SELECT arrayShingles(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 249, line 250) (in query: SELECT arrayShingles(-1);) 2025.06.13 15:43:14.064834 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 1, should be 2: In scope SELECT arrayShingles(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:14.096015 [ 8431 ] {c2a05dd3-cb4c-4d32-98d3-fefda16d81e7} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 444, line 445) (in query: SELECT dictGetFloat32();) 2025.06.13 15:43:14.107984 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:14.191171 [ 8442 ] {8f8bf84e-d751-4a30-9929-a39eb76e8d40} executeQuery: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1162, line 1163) (in query: SELECT replicate(NULL, NULL);) 2025.06.13 15:43:14.197527 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:14.212779 [ 8431 ] {ec7fdee1-dc7a-4009-83b9-79379d7d92aa} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetFloat32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 445, line 446) (in query: SELECT dictGetFloat32OrDefault();) 2025.06.13 15:43:14.213529 [ 5978 ] {00306164-f6c7-4b92-a518-2da4496261b0} executeQuery: Code: 43. DB::Exception: First argument of function 'arrayShuffle' must be array: In scope SELECT arrayShuffle(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 250, line 251) (in query: SELECT arrayShuffle(-1);) 2025.06.13 15:43:14.220280 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function 'arrayShuffle' must be array: In scope SELECT arrayShuffle(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:14.223620 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetFloat32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:14.327457 [ 8431 ] {981fb640-5bb8-42bc-9c29-43a861c498e6} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 446, line 447) (in query: SELECT dictGetFloat64();) 2025.06.13 15:43:14.340313 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:14.346964 [ 5978 ] {98d4539a-aa30-45c7-a9af-03b44a2aa1e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function arraySlice doesn't match: passed 1, should be 2 or 3: In scope SELECT arraySlice(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 251, line 252) (in query: SELECT arraySlice(-1);) 2025.06.13 15:43:14.378978 [ 2860 ] {548d06e4-af13-4b71-a641-8d2111f2255a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'bom' in scope SELECT * FROM bom ORDER BY a ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60298) (comment: 01258_bom_tsv.sh) (in query: SELECT * FROM bom ORDER BY a ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:43:14.451846 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arraySlice doesn't match: passed 1, should be 2 or 3: In scope SELECT arraySlice(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:14.454083 [ 2860 ] {548d06e4-af13-4b71-a641-8d2111f2255a} DynamicQueryHandler: Code: 60. DB::Exception: Unknown table expression identifier 'bom' in scope SELECT * FROM bom ORDER BY a ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:14.524421 [ 5978 ] {e44d6b04-ecad-4510-9bb8-96a2dc761b19} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arraySort must be array. Found Int8 instead: In scope SELECT arraySort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 252, line 253) (in query: SELECT arraySort(-1);) 2025.06.13 15:43:14.528744 [ 8442 ] {1f9aac12-48b4-4c52-a90c-f75c4c849514} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 2, should be 1: In scope SELECT reverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1164, line 1165) (in query: SELECT reverse(NULL, NULL);) 2025.06.13 15:43:14.544693 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arraySort must be array. Found Int8 instead: In scope SELECT arraySort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:14.551191 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 2, should be 1: In scope SELECT reverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:14.559161 [ 8431 ] {673e3d8d-f69b-45bf-af9a-ebb8e8f0b837} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetFloat64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 447, line 448) (in query: SELECT dictGetFloat64OrDefault();) 2025.06.13 15:43:14.581227 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetFloat64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:14.669192 [ 8442 ] {aadd895b-cec2-4cd1-9298-775d99dbf010} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 2, should be 1: In scope SELECT reverseUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1165, line 1166) (in query: SELECT reverseUTF8(NULL, NULL);) 2025.06.13 15:43:14.674587 [ 5978 ] {b7769fdc-ad7d-4e9a-b1fa-3512ebe7e363} executeQuery: Code: 42. DB::Exception: Function arraySplit needs at least 2 arguments, passed 1: In scope SELECT arraySplit(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 253, line 254) (in query: SELECT arraySplit(-1);) 2025.06.13 15:43:14.680528 [ 8431 ] {545e2138-fa2c-48cf-9299-068c623128eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 0, should be 2: In scope SELECT dictGetHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 448, line 449) (in query: SELECT dictGetHierarchy();) 2025.06.13 15:43:14.695184 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 2, should be 1: In scope SELECT reverseUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:14.695693 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 0, should be 2: In scope SELECT dictGetHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:14.695949 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function arraySplit needs at least 2 arguments, passed 1: In scope SELECT arraySplit(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:14.759248 [ 2860 ] {4ad49fc6-04e6-4ae1-b18a-b3f3750c39f6} executeQuery: Code: 60. DB::Exception: Table test_11.bom does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60302) (comment: 01258_bom_tsv.sh) (in query: DROP TABLE bom ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:43:14.768217 [ 2860 ] {4ad49fc6-04e6-4ae1-b18a-b3f3750c39f6} DynamicQueryHandler: Code: 60. DB::Exception: Table test_11.bom does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:14.785654 [ 8442 ] {bb28cd04-ebf4-4c7b-8abd-1966a1129c4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 2, should be 0: In scope SELECT revision(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1166, line 1167) (in query: SELECT revision(NULL, NULL);) 2025.06.13 15:43:14.809202 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 2, should be 0: In scope SELECT revision(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:14.817397 [ 8431 ] {03406fa1-96f4-4287-aa64-31fd89db7c77} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetIPv4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 449, line 450) (in query: SELECT dictGetIPv4();) 2025.06.13 15:43:14.824558 [ 5978 ] {a80f96c8-a75c-4c14-9db5-9f8c8db2e90c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'arr' to function 'arrayStringConcat'. Expected: Array, got: Int8: In scope SELECT arrayStringConcat(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 254, line 255) (in query: SELECT arrayStringConcat(-1);) 2025.06.13 15:43:14.829667 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetIPv4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:14.832904 [ 8099 ] {9b1fd87f-7c96-42e7-b645-a0a71fa137d7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:39070) (comment: 02021_create_database_with_comment.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_7;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:14.840542 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'arr' to function 'arrayStringConcat'. Expected: Array, got: Int8: In scope SELECT arrayStringConcat(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:14.852167 [ 8099 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:14.950681 [ 5978 ] {32e72061-97ae-4170-b2cc-b20e70451a9f} executeQuery: Code: 43. DB::Exception: The 1st and only argument for function arraySum must be array. Found Int8 instead: In scope SELECT arraySum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 255, line 256) (in query: SELECT arraySum(-1);) 2025.06.13 15:43:14.971366 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The 1st and only argument for function arraySum must be array. Found Int8 instead: In scope SELECT arraySum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:14.976496 [ 8431 ] {a5c1f8d1-5e6f-4dc8-b141-c3c87e477ade} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetIPv4OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 450, line 451) (in query: SELECT dictGetIPv4OrDefault();) 2025.06.13 15:43:14.983378 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetIPv4OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:15.024942 [ 5978 ] {11e68a7a-61eb-4510-b361-7df2a7789a1c} executeQuery: Code: 43. DB::Exception: Argument 0 for function arraySymmetricDifference must be an array but it has type Int8.: In scope SELECT arraySymmetricDifference(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 256, line 257) (in query: SELECT arraySymmetricDifference(-1);) 2025.06.13 15:43:15.029135 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function arraySymmetricDifference must be an array but it has type Int8.: In scope SELECT arraySymmetricDifference(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:15.034767 [ 8431 ] {620e4b45-9f9a-4d44-827a-c49184ced9f9} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 451, line 452) (in query: SELECT dictGetIPv6();) 2025.06.13 15:43:15.041235 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:15.100703 [ 5978 ] {cc3f467c-3c09-4bb9-ae57-a8b66f4657b0} executeQuery: Code: 43. DB::Exception: Argument 0 for function arrayUnion must be an array but it has type Int8.: In scope SELECT arrayUnion(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 257, line 258) (in query: SELECT arrayUnion(-1);) 2025.06.13 15:43:15.111518 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function arrayUnion must be an array but it has type Int8.: In scope SELECT arrayUnion(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:15.125515 [ 8431 ] {340489ab-cd48-47c0-b9fb-1c131cead1a5} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetIPv6OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 452, line 453) (in query: SELECT dictGetIPv6OrDefault();) 2025.06.13 15:43:15.138664 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetIPv6OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:15.239012 [ 5978 ] {bdb38c0f-7af9-4fa1-b697-336a0aaa5d2f} executeQuery: Code: 43. DB::Exception: All arguments for function arrayUniq must be arrays but argument 1 has type Int8.: In scope SELECT arrayUniq(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 258, line 259) (in query: SELECT arrayUniq(-1);) 2025.06.13 15:43:15.270713 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: All arguments for function arrayUniq must be arrays but argument 1 has type Int8.: In scope SELECT arrayUniq(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:15.308016 [ 8431 ] {1e786f70-e1be-48de-926f-bd55854a5c0c} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 453, line 454) (in query: SELECT dictGetInt16();) 2025.06.13 15:43:15.327564 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:15.431885 [ 5978 ] {a78fe58a-0d7e-41c6-81d4-0b1881481228} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 1, should be 2: In scope SELECT arrayWithConstant(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 259, line 260) (in query: SELECT arrayWithConstant(-1);) 2025.06.13 15:43:15.461382 [ 8431 ] {f599714a-aa71-49e1-8253-4b9c028f7980} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 454, line 455) (in query: SELECT dictGetInt16OrDefault();) 2025.06.13 15:43:15.470802 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:15.505924 [ 3894 ] {0de5b5c2-cdaf-4ada-b3b3-1a234a4fa6a6} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58278) (comment: 01514_input_format_tsv_enum_as_number_setting.sql) (query 2, line 3) (in query: CREATE TABLE table_with_enum_column_for_tsv_insert ( Id Int32, Value Enum('ef' = 1, 'es' = 2) ) ENGINE=Memory();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:15.515599 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 1, should be 2: In scope SELECT arrayWithConstant(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:15.540847 [ 3894 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:15.552328 [ 8431 ] {5f4513db-d6a7-4065-bdf2-ccfd590d4095} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 455, line 456) (in query: SELECT dictGetInt32();) 2025.06.13 15:43:15.571471 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:15.617121 [ 5978 ] {589cdc87-957c-4c36-a6ed-11f766927f80} executeQuery: Code: 43. DB::Exception: Argument 1 of function arrayZip must be array. Found Int8 instead.: In scope SELECT arrayZip(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 260, line 261) (in query: SELECT arrayZip(-1);) 2025.06.13 15:43:15.638140 [ 8431 ] {cb04b3bf-438d-4f49-83b3-ca0842383e3f} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 456, line 457) (in query: SELECT dictGetInt32OrDefault();) 2025.06.13 15:43:15.641423 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 of function arrayZip must be array. Found Int8 instead.: In scope SELECT arrayZip(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:15.692158 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:15.747433 [ 5978 ] {f6d81252-0dc4-4f93-9a81-edc0f6685058} executeQuery: Code: 43. DB::Exception: Argument 1 of function arrayZipUnaligned must be array. Found Int8 instead.: In scope SELECT arrayZipUnaligned(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 261, line 262) (in query: SELECT arrayZipUnaligned(-1);) 2025.06.13 15:43:15.766111 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 of function arrayZipUnaligned must be array. Found Int8 instead.: In scope SELECT arrayZipUnaligned(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:15.780936 [ 8431 ] {735fdeb0-120b-4599-811d-9c4e71075999} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 457, line 458) (in query: SELECT dictGetInt64();) 2025.06.13 15:43:15.793503 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:15.813329 [ 8442 ] {de540207-39ab-4222-a12e-da7d0d65da85} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 2, should be 1: In scope SELECT roundAge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1172, line 1173) (in query: SELECT roundAge(NULL, NULL);) 2025.06.13 15:43:15.897267 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 2, should be 1: In scope SELECT roundAge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:15.922595 [ 8431 ] {42fc0f22-de78-48b9-b0e8-afa524f42423} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 458, line 459) (in query: SELECT dictGetInt64OrDefault();) 2025.06.13 15:43:15.932621 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:16.074853 [ 5978 ] {dc1341d1-353d-49ff-ae2c-cc0238a2d4d6} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 263, line 264) (in query: SELECT array_concat_agg(-1);) 2025.06.13 15:43:16.084145 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:16.099308 [ 8431 ] {03c67600-83e8-4c18-b47f-ba0c7f0a9253} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 459, line 460) (in query: SELECT dictGetInt8();) 2025.06.13 15:43:16.114812 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:16.239907 [ 5978 ] {b557dac7-994f-4ccf-9bdf-da908b766b12} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function ascii: In scope SELECT ascii(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 264, line 265) (in query: SELECT ascii(-1);) 2025.06.13 15:43:16.246253 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function ascii: In scope SELECT ascii(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:16.270023 [ 8431 ] {547c496a-4b5a-4540-a62f-d3c141cba39c} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 460, line 461) (in query: SELECT dictGetInt8OrDefault();) 2025.06.13 15:43:16.296251 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:16.383184 [ 7755 ] {9d61646a-a864-40dc-b477-0cec9d5edbdd} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58346) (comment: 01825_new_type_json_parallel_insert.sql) (query 3, line 5) (in query: CREATE TABLE t_json_parallel (`data` JSON) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 2812, min_bytes_for_wide_part = 1065174445, ratio_of_defaults_for_sparse_serialization = 0.33075588941574097, 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 = 14764076, compact_parts_max_granules_to_buffer = 238, compact_parts_merge_max_bytes_to_prefetch_part = 15938999, merge_max_block_size = 5085, old_parts_lifetime = 284., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3650070098, index_granularity_bytes = 29752589, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 18, 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 = 31530, primary_key_compress_block_size = 38974, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:16.402621 [ 7755 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:16.411393 [ 8431 ] {ee91aed4-b2e0-4d69-b071-6bd1baa1d3d5} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 461, line 462) (in query: SELECT dictGetOrDefault();) 2025.06.13 15:43:16.427989 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:16.428407 [ 8442 ] {929b0114-4456-4f20-a293-c223d9a645cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 2, should be 1: In scope SELECT roundDuration(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1175, line 1176) (in query: SELECT roundDuration(NULL, NULL);) 2025.06.13 15:43:16.447628 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 2, should be 1: In scope SELECT roundDuration(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:16.549988 [ 8442 ] {29422b82-fcf6-4ccf-b18a-7202c5e4edb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 2, should be 1: In scope SELECT roundToExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1176, line 1177) (in query: SELECT roundToExp2(NULL, NULL);) 2025.06.13 15:43:16.550659 [ 8431 ] {e564759e-b16b-4f87-8da3-bff2a2ec6089} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 462, line 463) (in query: SELECT dictGetOrNull();) 2025.06.13 15:43:16.555544 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 2, should be 1: In scope SELECT roundToExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:16.557410 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:16.629112 [ 8431 ] {f3913402-ac2b-4cae-b32a-aa585396f01e} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 463, line 464) (in query: SELECT dictGetString();) 2025.06.13 15:43:16.655737 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:16.664971 [ 8442 ] {95c254c9-01d8-42c6-91f6-6abaa2396cf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 2, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1177, line 1178) (in query: SELECT rowNumberInAllBlocks(NULL, NULL);) 2025.06.13 15:43:16.692386 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 2, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:16.753256 [ 8431 ] {27db189d-c2ff-48e3-a85d-a1a4e69f2f6c} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetStringOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 464, line 465) (in query: SELECT dictGetStringOrDefault();) 2025.06.13 15:43:16.772199 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetStringOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:16.806331 [ 8442 ] {37645ff3-d5f2-4a91-8e30-2469dd05e9cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 2, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1178, line 1179) (in query: SELECT rowNumberInBlock(NULL, NULL);) 2025.06.13 15:43:16.852190 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 2, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:16.972436 [ 8431 ] {9a2a784c-9938-454d-ac3e-b8cff01a9257} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 465, line 466) (in query: SELECT dictGetUInt16();) 2025.06.13 15:43:16.980038 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:17.043330 [ 8442 ] {6204ace6-8c4d-4d05-9db2-b69b3aef0fb7} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1179, line 1180) (in query: SELECT row_number(NULL, NULL);) 2025.06.13 15:43:17.052057 [ 8431 ] {0be52ea9-6d05-4128-89aa-f3372eb63a97} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 466, line 467) (in query: SELECT dictGetUInt16OrDefault();) 2025.06.13 15:43:17.060745 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:43:17.074736 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:17.082379 [ 8430 ] {273cca73-e6f2-49bd-931d-602c81f1d820} 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.20286.altinityantalya (altinity build)) (from [::1]:58252) (comment: 03240_quantile_exact_weighted_interpolated.sql) (query 10, line 33) (in query: SELECT quantileExactWeightedInterpolated(0.6)(a, 1), quantileExactWeightedInterpolated(0.6)(b, 2), quantileExactWeightedInterpolated(0.6)(c, 3) FROM decimal WHERE a >= 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:43:17.105503 [ 8430 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:43:17.142124 [ 5978 ] {4178d31e-fda8-4219-879f-88ece1ae3bc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 1, should be 2: In scope SELECT atan2(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 269, line 270) (in query: SELECT atan2(-1);) 2025.06.13 15:43:17.147202 [ 8431 ] {a64d58a3-5877-4b16-892b-cfba257a3cb3} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 467, line 468) (in query: SELECT dictGetUInt32();) 2025.06.13 15:43:17.166504 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:17.183191 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 1, should be 2: In scope SELECT atan2(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:17.281046 [ 8431 ] {7ba4e917-d961-49ec-9ab3-b9c877fe0c0f} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 468, line 469) (in query: SELECT dictGetUInt32OrDefault();) 2025.06.13 15:43:17.287755 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:17.326662 [ 8442 ] {e2a07af8-bc18-4bbd-953d-612e2d9d1758} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1181, line 1183) (in query: SELECT runningAccumulate(NULL, NULL);) 2025.06.13 15:43:17.348588 [ 8442 ] {} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:43:17.371145 [ 8431 ] {d285e4f5-ca06-4136-bc3b-7a41554fb944} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 469, line 470) (in query: SELECT dictGetUInt64();) 2025.06.13 15:43:17.383569 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:17.448306 [ 8442 ] {08c26b8a-9fe0-43db-83ac-f0eb1642ed2f} executeQuery: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1182, line 1184) (in query: SELECT runningConcurrency(NULL, NULL);) 2025.06.13 15:43:17.472108 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:17.473055 [ 8431 ] {c7b6c375-09a5-46fb-8b7f-a6a34845513d} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 470, line 471) (in query: SELECT dictGetUInt64OrDefault();) 2025.06.13 15:43:17.496050 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:17.624069 [ 5978 ] {29708f9d-4660-4c04-a728-7882b9d5adc8} executeQuery: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 272, line 273) (in query: SELECT avgWeighted(-1);) 2025.06.13 15:43:17.644467 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:17.651338 [ 8431 ] {ec763e17-2e48-4398-a108-1ec79991117e} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 471, line 472) (in query: SELECT dictGetUInt8();) 2025.06.13 15:43:17.666156 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:17.674885 [ 8442 ] {bef191a8-274c-454d-a2c1-f7ec9277a9e4} 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.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1183, line 1185) (in query: SELECT runningDifference(NULL, NULL);) 2025.06.13 15:43:17.692647 [ 8442 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:43:17.721880 [ 8431 ] {5c7850b7-de7e-4121-9142-405f4399ae09} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 472, line 473) (in query: SELECT dictGetUInt8OrDefault();) 2025.06.13 15:43:17.737845 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:17.743730 [ 5978 ] {e1d3630f-5786-4ef2-91d0-2dffb2188d7c} executeQuery: Code: 42. DB::Exception: Function bar requires from 3 or 4 parameters: value, min_value, max_value, [max_width_of_bar = 80]. Passed 1.: In scope SELECT bar(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 273, line 274) (in query: SELECT bar(-1);) 2025.06.13 15:43:17.776666 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function bar requires from 3 or 4 parameters: value, min_value, max_value, [max_width_of_bar = 80]. Passed 1.: In scope SELECT bar(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:17.798105 [ 8442 ] {8f4a31f2-3f67-4903-b752-64e5b2128ffe} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1184, line 1186) (in query: SELECT runningDifferenceStartingWithFirstValue(NULL, NULL);) 2025.06.13 15:43:17.814392 [ 8442 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:43:17.839206 [ 8431 ] {0fbc202b-573b-496e-adf1-b8d558435820} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 473, line 474) (in query: SELECT dictGetUUID();) 2025.06.13 15:43:17.856656 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:17.889814 [ 8442 ] {eb4b0874-d14d-4882-9f8e-eb7fdf975586} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 2, should be 3: In scope SELECT s2CapContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1185, line 1187) (in query: SELECT s2CapContains(NULL, NULL);) 2025.06.13 15:43:17.907747 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 2, should be 3: In scope SELECT s2CapContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:17.979806 [ 8442 ] {0e9bcb99-6310-4ce8-bcf1-fbc707dc1b7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 2, should be 4: In scope SELECT s2CapUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1186, line 1188) (in query: SELECT s2CapUnion(NULL, NULL);) 2025.06.13 15:43:17.980255 [ 5978 ] {bf89d68b-7ff7-4cd4-b321-997c270293eb} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'arg' to function 'base58Decode'. Expected: String or FixedString, got: Int8: In scope SELECT base58Decode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 274, line 275) (in query: SELECT base58Decode(-1);) 2025.06.13 15:43:17.980387 [ 8431 ] {bcdcfdfb-9a23-4f1e-9778-805fbe998592} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUUIDOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 474, line 475) (in query: SELECT dictGetUUIDOrDefault();) 2025.06.13 15:43:17.992837 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'arg' to function 'base58Decode'. Expected: String or FixedString, got: Int8: In scope SELECT base58Decode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:17.994103 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUUIDOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:17.994188 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 2, should be 4: In scope SELECT s2CapUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:18.076148 [ 5978 ] {b1a5e64c-ebbd-431a-86a2-855f899c1c5d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'arg' to function 'base58Encode'. Expected: String or FixedString, got: Int8: In scope SELECT base58Encode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 275, line 276) (in query: SELECT base58Encode(-1);) 2025.06.13 15:43:18.092172 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'arg' to function 'base58Encode'. Expected: String or FixedString, got: Int8: In scope SELECT base58Encode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:18.123980 [ 8431 ] {2d650da8-587f-4816-9fac-bd4deaef6a95} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictHas: In scope SELECT dictHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 475, line 476) (in query: SELECT dictHas();) 2025.06.13 15:43:18.156727 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictHas: In scope SELECT dictHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:18.211916 [ 5978 ] {ce84533f-e08a-4392-b8d2-b2d5eabc1570} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Decode'. Expected: String or FixedString, got: Int8: In scope SELECT base64Decode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 276, line 277) (in query: SELECT base64Decode(-1);) 2025.06.13 15:43:18.236194 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Decode'. Expected: String or FixedString, got: Int8: In scope SELECT base64Decode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:18.276757 [ 8431 ] {1d7fe6b6-6e0b-4f12-b158-281bfe6e63c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 0, should be 3: In scope SELECT dictIsIn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 476, line 477) (in query: SELECT dictIsIn();) 2025.06.13 15:43:18.289448 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 0, should be 3: In scope SELECT dictIsIn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:18.312586 [ 8442 ] {93b03a1a-bf7d-4b4e-a419-3d4b869a88b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 2, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1188, line 1190) (in query: SELECT s2GetNeighbors(NULL, NULL);) 2025.06.13 15:43:18.317390 [ 5978 ] {f8519f15-bd07-4c46-81e2-eeaf58f6385c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Encode'. Expected: String or FixedString, got: Int8: In scope SELECT base64Encode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 277, line 278) (in query: SELECT base64Encode(-1);) 2025.06.13 15:43:18.321856 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 2, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:18.341847 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64Encode'. Expected: String or FixedString, got: Int8: In scope SELECT base64Encode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:18.392972 [ 8442 ] {093f078e-028c-4c11-ac5f-9b8f0dc868a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 2, should be 3: In scope SELECT s2RectAdd(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1189, line 1191) (in query: SELECT s2RectAdd(NULL, NULL);) 2025.06.13 15:43:18.412864 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 2, should be 3: In scope SELECT s2RectAdd(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:18.448257 [ 5978 ] {742b9b11-6406-4ba3-9fa1-eb82215195fd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64URLDecode'. Expected: String or FixedString, got: Int8: In scope SELECT base64URLDecode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 278, line 279) (in query: SELECT base64URLDecode(-1);) 2025.06.13 15:43:18.468933 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64URLDecode'. Expected: String or FixedString, got: Int8: In scope SELECT base64URLDecode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:18.564972 [ 8431 ] {2cfea341-cdac-4569-9ffd-439b7ecbbf37} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 0, should be 2: In scope SELECT distanceL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 478, line 479) (in query: SELECT distanceL1();) 2025.06.13 15:43:18.568940 [ 5978 ] {84c7780f-abb4-45f6-9c02-0cfc38efe140} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64URLEncode'. Expected: String or FixedString, got: Int8: In scope SELECT base64URLEncode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 279, line 280) (in query: SELECT base64URLEncode(-1);) 2025.06.13 15:43:18.572965 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 0, should be 2: In scope SELECT distanceL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:18.578106 [ 8442 ] {6b9805e3-fd39-4b1b-a603-ccb6834dcfd2} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 2, should be 3: In scope SELECT s2RectContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1190, line 1192) (in query: SELECT s2RectContains(NULL, NULL);) 2025.06.13 15:43:18.584018 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'base64URLEncode'. Expected: String or FixedString, got: Int8: In scope SELECT base64URLEncode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:18.589797 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 2, should be 3: In scope SELECT s2RectContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:18.714650 [ 8442 ] {65210b76-fd3d-4580-9d63-5d66534c4bcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 2, should be 4: In scope SELECT s2RectIntersection(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1191, line 1193) (in query: SELECT s2RectIntersection(NULL, NULL);) 2025.06.13 15:43:18.731562 [ 5978 ] {a0b4e27b-98e8-4727-b5d6-1ed6d210920e} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function basename: In scope SELECT basename(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 280, line 281) (in query: SELECT basename(-1);) 2025.06.13 15:43:18.739940 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 2, should be 4: In scope SELECT s2RectIntersection(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:18.782701 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function basename: In scope SELECT basename(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:18.785816 [ 8431 ] {d29ae41a-619d-4e7d-a6c3-67bf724ace13} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 0, should be 2: In scope SELECT distanceL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 479, line 480) (in query: SELECT distanceL2();) 2025.06.13 15:43:18.817635 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 0, should be 2: In scope SELECT distanceL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:18.857317 [ 8442 ] {8aa9d54b-1af9-431d-be22-a6f7fc5439ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 2, should be 4: In scope SELECT s2RectUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1192, line 1194) (in query: SELECT s2RectUnion(NULL, NULL);) 2025.06.13 15:43:18.885722 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 2, should be 4: In scope SELECT s2RectUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:18.954028 [ 8431 ] {e12ff47b-9448-4f55-a5fb-8e32be6c16ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 0, should be 2: In scope SELECT distanceL2Squared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 480, line 481) (in query: SELECT distanceL2Squared();) 2025.06.13 15:43:19.004492 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 0, should be 2: In scope SELECT distanceL2Squared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:19.088212 [ 8442 ] {57f45fcb-c6ee-498c-9d6d-bc81bea996c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 2, should be 1: In scope SELECT s2ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1193, line 1195) (in query: SELECT s2ToGeo(NULL, NULL);) 2025.06.13 15:43:19.107592 [ 5978 ] {bfe977f2-4b67-4016-bae7-1a48ac8a4746} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 1, should be 2: In scope SELECT bitAnd(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 282, line 283) (in query: SELECT bitAnd(-1);) 2025.06.13 15:43:19.120023 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 2, should be 1: In scope SELECT s2ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:19.134777 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 1, should be 2: In scope SELECT bitAnd(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:19.155962 [ 8431 ] {2f42acea-a7f1-4828-8045-3c256c557d5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 0, should be 2: In scope SELECT distanceLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 481, line 482) (in query: SELECT distanceLinf();) 2025.06.13 15:43:19.200196 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 0, should be 2: In scope SELECT distanceLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:19.353344 [ 18602 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:19.354439 [ 18602 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:43:19.381106 [ 8431 ] {080f92f8-69c6-4598-ba8a-8bcb774b5bbd} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 0, should be 3: In scope SELECT distanceLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 482, line 483) (in query: SELECT distanceLp();) 2025.06.13 15:43:19.414951 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 0, should be 3: In scope SELECT distanceLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:19.524178 [ 5978 ] {966c0892-191a-4186-92f0-2c86ab5e3674} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 1, should be 2: In scope SELECT bitHammingDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 284, line 285) (in query: SELECT bitHammingDistance(-1);) 2025.06.13 15:43:19.527250 [ 8431 ] {bcb2aa73-8359-4f8b-a8a9-52ec26b8990f} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctDynamicTypes. Expected single argument with type Dynamic, got 0 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 483, line 484) (in query: SELECT distinctDynamicTypes();) 2025.06.13 15:43:19.538658 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 1, should be 2: In scope SELECT bitHammingDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:19.572435 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctDynamicTypes. Expected single argument with type Dynamic, got 0 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:19.693458 [ 8431 ] {6053673a-bfe1-40f5-8a05-d838bb6835e2} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPaths. Expected single argument with type JSON, got 0 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 484, line 485) (in query: SELECT distinctJSONPaths();) 2025.06.13 15:43:19.726482 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPaths. Expected single argument with type JSON, got 0 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:19.892642 [ 5978 ] {b3a6d9fb-b415-41d0-a3a4-2c8ee6bb596a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 1, should be 2: In scope SELECT bitOr(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 286, line 287) (in query: SELECT bitOr(-1);) 2025.06.13 15:43:19.895064 [ 8431 ] {12bc9505-6cc2-4b89-85d9-75bb33e5e446} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPathsAndTypes. Expected single argument with type JSON, got 0 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 485, line 486) (in query: SELECT distinctJSONPathsAndTypes();) 2025.06.13 15:43:19.898120 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 1, should be 2: In scope SELECT bitOr(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:19.947849 [ 18602 ] {ce9a51f4-d754-4cd1-8478-b16ef4a1e687} executeQuery: Code: 60. DB::Exception: Table test_11.t_json_6 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58424) (comment: 01825_type_json_6.sh) (query 1, line 1) (in query: INSERT INTO t_json_6 FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:19.973031 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPathsAndTypes. Expected single argument with type JSON, got 0 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:19.980513 [ 18602 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.t_json_6 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:20.060014 [ 8431 ] {b7a876d3-105c-424c-9930-850040016785} executeQuery: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 0, should be 2: In scope SELECT divide(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 486, line 487) (in query: SELECT divide();) 2025.06.13 15:43:20.102814 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 0, should be 2: In scope SELECT divide(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:20.221739 [ 5978 ] {5924abb4-70f8-4306-be6c-932be100b8ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 1, should be 2: In scope SELECT bitRotateLeft(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 288, line 289) (in query: SELECT bitRotateLeft(-1);) 2025.06.13 15:43:20.237821 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 1, should be 2: In scope SELECT bitRotateLeft(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:20.254439 [ 8431 ] {6513a14a-3d84-45eb-9d00-c6a47e0f8a9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function divideDecimal does not match: 2 or 3 expected: In scope SELECT divideDecimal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 487, line 488) (in query: SELECT divideDecimal();) 2025.06.13 15:43:20.275406 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divideDecimal does not match: 2 or 3 expected: In scope SELECT divideDecimal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:20.395383 [ 8442 ] {43c28d50-e494-47de-8468-a379ed275c6a} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1198, line 1200) (in query: SELECT sequenceNextNode(NULL, NULL);) 2025.06.13 15:43:20.404364 [ 8442 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.06.13 15:43:20.423805 [ 5978 ] {ab4f0746-3978-4fca-9ef5-8797ef6e9b97} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 1, should be 2: In scope SELECT bitRotateRight(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 289, line 290) (in query: SELECT bitRotateRight(-1);) 2025.06.13 15:43:20.423878 [ 8431 ] {6da74a71-0d5e-4525-a299-da097b59e62a} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 0, should be 1: In scope SELECT domain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 488, line 489) (in query: SELECT domain();) 2025.06.13 15:43:20.443598 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 0, should be 1: In scope SELECT domain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:20.483347 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 1, should be 2: In scope SELECT bitRotateRight(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:20.612950 [ 8431 ] {01091501-3a35-4626-8dc0-c129f8a90486} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 0, should be 1: In scope SELECT domainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 489, line 490) (in query: SELECT domainRFC();) 2025.06.13 15:43:20.635191 [ 4107 ] {85a8f171-e366-4127-b130-5efcc2d6ccc8} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_6' in scope SELECT DISTINCT toTypeName(data) FROM t_json_6. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58454) (comment: 01825_type_json_6.sh) (query 1, line 1) (in query: SELECT DISTINCT toTypeName(data) FROM t_json_6;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:43:20.638115 [ 5978 ] {8dcf8def-a235-431c-b1ae-cb290a35c2b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 1, should be 2: In scope SELECT bitShiftLeft(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 290, line 291) (in query: SELECT bitShiftLeft(-1);) 2025.06.13 15:43:20.638312 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 0, should be 1: In scope SELECT domainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:20.642772 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 1, should be 2: In scope SELECT bitShiftLeft(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:20.663027 [ 4107 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_6' in scope SELECT DISTINCT toTypeName(data) FROM t_json_6. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:43:20.731612 [ 5978 ] {77c20859-61f8-433d-a5fe-914b2c7399c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 1, should be 2: In scope SELECT bitShiftRight(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 291, line 292) (in query: SELECT bitShiftRight(-1);) 2025.06.13 15:43:20.745074 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 1, should be 2: In scope SELECT bitShiftRight(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:20.772445 [ 8431 ] {142b84e1-1b4c-4616-a1d8-075bab9574fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 0, should be 1: In scope SELECT domainWithoutWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 490, line 491) (in query: SELECT domainWithoutWWW();) 2025.06.13 15:43:20.792213 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 0, should be 1: In scope SELECT domainWithoutWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:20.832494 [ 5978 ] {ccf88469-00c8-455e-865f-068f9218bf30} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT bitSlice(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 292, line 293) (in query: SELECT bitSlice(-1);) 2025.06.13 15:43:20.877305 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT bitSlice(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:20.913617 [ 8431 ] {51962719-256d-445d-8720-036f74fb1b22} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 0, should be 1: In scope SELECT domainWithoutWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 491, line 492) (in query: SELECT domainWithoutWWWRFC();) 2025.06.13 15:43:20.955853 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 0, should be 1: In scope SELECT domainWithoutWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.043650 [ 8442 ] {4b4e62a7-bf2a-43d2-a544-9a8b2b33015f} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 2, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1201, line 1203) (in query: SELECT seriesPeriodDetectFFT(NULL, NULL);) 2025.06.13 15:43:21.060940 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 2, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.063428 [ 8431 ] {07a64b7c-baa3-48d9-b990-45ef55b2e053} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 0, should be 2: In scope SELECT dotProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 492, line 493) (in query: SELECT dotProduct();) 2025.06.13 15:43:21.072547 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 0, should be 2: In scope SELECT dotProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.108195 [ 5978 ] {ac26c3ff-7266-4fbd-b81b-3c430b402b5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 1, should be 2: In scope SELECT bitTest(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 293, line 294) (in query: SELECT bitTest(-1);) 2025.06.13 15:43:21.111922 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 1, should be 2: In scope SELECT bitTest(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.165430 [ 8442 ] {f804863a-5545-4336-85a4-0119e4e36807} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1202, line 1204) (in query: SELECT serverTimeZone(NULL, NULL);) 2025.06.13 15:43:21.169771 [ 7755 ] {08ae9716-c674-4350-b9ba-38f83292f77b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_6' in scope SELECT data.key, data.out.type, data.out.value, data.out.outputs.index, data.out.outputs.n FROM t_json_6 ORDER BY data.key ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58468) (comment: 01825_type_json_6.sh) (query 1, line 1) (in query: SELECT data.key, data.out.type, data.out.value, data.out.outputs.index, data.out.outputs.n FROM t_json_6 ORDER BY data.key), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:43:21.199834 [ 7755 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_6' in scope SELECT data.key, data.out.type, data.out.value, data.out.outputs.index, data.out.outputs.n FROM t_json_6 ORDER BY data.key ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:43:21.206468 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.246739 [ 8431 ] {987735bf-438c-45ae-8271-008deb40ead9} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 0, should be 1: In scope SELECT dumpColumnStructure(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 493, line 494) (in query: SELECT dumpColumnStructure();) 2025.06.13 15:43:21.259362 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 0, should be 1: In scope SELECT dumpColumnStructure(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.264372 [ 5978 ] {e8db6f04-9672-43a1-b3b8-b6fc86069ea8} executeQuery: Code: 35. DB::Exception: Number of arguments for function bitTestAll doesn't match: passed 1, should be at least 2.: In scope SELECT bitTestAll(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 294, line 295) (in query: SELECT bitTestAll(-1);) 2025.06.13 15:43:21.284208 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function bitTestAll doesn't match: passed 1, should be at least 2.: In scope SELECT bitTestAll(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:43:21.324221 [ 8442 ] {3b4d6a06-58fc-42e9-b5fb-bd2bab8c3b7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1203, line 1205) (in query: SELECT serverTimezone(NULL, NULL);) 2025.06.13 15:43:21.329413 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.408948 [ 8431 ] {f6ed3d6e-675b-459f-8546-049b494d246b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 0, should be 2: In scope SELECT dynamicElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 494, line 495) (in query: SELECT dynamicElement();) 2025.06.13 15:43:21.409217 [ 5978 ] {fe9986f6-a3ec-4a99-ba10-a2fc91703088} executeQuery: Code: 35. DB::Exception: Number of arguments for function bitTestAny doesn't match: passed 1, should be at least 2.: In scope SELECT bitTestAny(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 295, line 296) (in query: SELECT bitTestAny(-1);) 2025.06.13 15:43:21.416198 [ 8442 ] {596b4d38-8b35-4ff4-885b-3aadb79c8337} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 2, should be 0: In scope SELECT serverUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1204, line 1206) (in query: SELECT serverUUID(NULL, NULL);) 2025.06.13 15:43:21.429429 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 0, should be 2: In scope SELECT dynamicElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.429854 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function bitTestAny doesn't match: passed 1, should be at least 2.: In scope SELECT bitTestAny(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:43:21.440358 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 2, should be 0: In scope SELECT serverUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.621887 [ 8442 ] {eced02ed-83c8-4dd5-ae9e-cb078e498b31} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 2, should be 0: In scope SELECT shardCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1205, line 1207) (in query: SELECT shardCount(NULL, NULL);) 2025.06.13 15:43:21.622169 [ 8431 ] {19f95621-319f-49ba-8560-f7f5de4bf8ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 0, should be 1: In scope SELECT dynamicType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 495, line 496) (in query: SELECT dynamicType();) 2025.06.13 15:43:21.644219 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 2, should be 0: In scope SELECT shardCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.658649 [ 5978 ] {bed8f117-dd9d-4060-9ede-1c5bb817c8e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 1, should be 2: In scope SELECT bitXor(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 296, line 297) (in query: SELECT bitXor(-1);) 2025.06.13 15:43:21.677081 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 0, should be 1: In scope SELECT dynamicType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.678061 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 1, should be 2: In scope SELECT bitXor(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.748198 [ 7279 ] {61d5809c-ecef-472f-a509-dd943955b730} executeQuery: Code: 60. DB::Exception: Table test_11.t_json_6 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58498) (comment: 01825_type_json_6.sh) (query 1, line 1) (in query: DROP TABLE t_json_6;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:43:21.764587 [ 5978 ] {1ee98d18-89e0-49cb-acd2-5be3e47e2790} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 1, should be 2: In scope SELECT bitmapAnd(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 297, line 298) (in query: SELECT bitmapAnd(-1);) 2025.06.13 15:43:21.784949 [ 7279 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.t_json_6 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:43:21.796025 [ 8442 ] {44c6ad9f-c5ff-4f96-8643-768c8dd1b447} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 2, should be 0: In scope SELECT shardNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1206, line 1208) (in query: SELECT shardNum(NULL, NULL);) 2025.06.13 15:43:21.796154 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 1, should be 2: In scope SELECT bitmapAnd(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.816304 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 2, should be 0: In scope SELECT shardNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.960463 [ 4171 ] {a414ef35-0dfc-4340-982d-dde0ae593676} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'N' to function 'ceil'. Expected: The number of decimal places to round to, got: UInt256: In scope SELECT materialize(10.1) AS x, ceil(x, toUInt256(123)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58276) (comment: 03165_round_scale_as_column.sql) (query 93, line 124) (in query: SELECT materialize(10.1) AS x, ceil(x, toUInt256(123));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::FunctionRounding::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018a4216a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:43:21.967742 [ 8442 ] {49b84d4c-df2f-4549-baba-57b3c6f43cd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 2, should be 0: In scope SELECT showCertificate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1207, line 1209) (in query: SELECT showCertificate(NULL, NULL);) 2025.06.13 15:43:21.993820 [ 5978 ] {cb21f95c-8077-49e6-8201-601628191b1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapAndCardinality(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 298, line 299) (in query: SELECT bitmapAndCardinality(-1);) 2025.06.13 15:43:21.993892 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 2, should be 0: In scope SELECT showCertificate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:21.994650 [ 4171 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'N' to function 'ceil'. Expected: The number of decimal places to round to, got: UInt256: In scope SELECT materialize(10.1) AS x, ceil(x, toUInt256(123)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::FunctionRounding::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018a4216a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:43:22.015505 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapAndCardinality(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:22.101667 [ 8431 ] {e9e9083d-6587-4073-9869-172766d05c4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 0, should be 2: In scope SELECT editDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 497, line 498) (in query: SELECT editDistance();) 2025.06.13 15:43:22.107626 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 0, should be 2: In scope SELECT editDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:22.122966 [ 8442 ] {7d4e3bfb-ea77-4d01-b33f-672905abacba} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 2, should be 1: In scope SELECT sigmoid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1208, line 1210) (in query: SELECT sigmoid(NULL, NULL);) 2025.06.13 15:43:22.137609 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 2, should be 1: In scope SELECT sigmoid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:22.140527 [ 5978 ] {cef927a3-4d3c-4e88-8c60-2f7997a61027} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 1, should be 2: In scope SELECT bitmapAndnot(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 299, line 300) (in query: SELECT bitmapAndnot(-1);) 2025.06.13 15:43:22.170360 [ 8431 ] {aef4b8b2-f736-48be-a25e-dd31f39ee1c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT editDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 498, line 499) (in query: SELECT editDistanceUTF8();) 2025.06.13 15:43:22.170645 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 1, should be 2: In scope SELECT bitmapAndnot(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:22.196015 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT editDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:22.263822 [ 8442 ] {9a735653-efb2-4fe3-bf31-ed0870eb6f62} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 2, should be 1: In scope SELECT sign(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1209, line 1211) (in query: SELECT sign(NULL, NULL);) 2025.06.13 15:43:22.284032 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 2, should be 1: In scope SELECT sign(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:22.287557 [ 5978 ] {eb39e07a-6532-4111-b0ef-2aef0a7b4822} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapAndnotCardinality(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 300, line 301) (in query: SELECT bitmapAndnotCardinality(-1);) 2025.06.13 15:43:22.300538 [ 8431 ] {7ff73f1c-9eaa-4342-85c3-dca9c8929600} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 0, should be 1: In scope SELECT empty(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 499, line 500) (in query: SELECT empty();) 2025.06.13 15:43:22.316448 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 0, should be 1: In scope SELECT empty(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:22.355927 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapAndnotCardinality(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:22.482400 [ 5978 ] {f75ed547-1480-4b22-9d6a-ba744651682b} executeQuery: Code: 43. DB::Exception: First argument for function bitmapBuild must be an array but it has type Int8.: In scope SELECT bitmapBuild(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 301, line 302) (in query: SELECT bitmapBuild(-1);) 2025.06.13 15:43:22.499344 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapBuild must be an array but it has type Int8.: In scope SELECT bitmapBuild(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:22.630703 [ 5978 ] {711735f6-f988-4a10-8058-0d226fa3284c} executeQuery: Code: 43. DB::Exception: First argument for function bitmapCardinality must be a bitmap but it has type Int8.: In scope SELECT bitmapCardinality(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 302, line 303) (in query: SELECT bitmapCardinality(-1);) 2025.06.13 15:43:22.644614 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapCardinality must be a bitmap but it has type Int8.: In scope SELECT bitmapCardinality(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:22.781606 [ 5978 ] {4d1e1c24-11a2-4128-a89b-379e752868bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 1, should be 2: In scope SELECT bitmapContains(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 303, line 304) (in query: SELECT bitmapContains(-1);) 2025.06.13 15:43:22.800084 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 1, should be 2: In scope SELECT bitmapContains(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:22.895544 [ 5978 ] {940c017f-15fa-41e8-ad10-3e928f16a073} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 1, should be 2: In scope SELECT bitmapHasAll(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 304, line 305) (in query: SELECT bitmapHasAll(-1);) 2025.06.13 15:43:22.902250 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 1, should be 2: In scope SELECT bitmapHasAll(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:23.136338 [ 5978 ] {d4a94657-b82e-4e51-a118-6d4a2d30486f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 1, should be 2: In scope SELECT bitmapHasAny(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 305, line 306) (in query: SELECT bitmapHasAny(-1);) 2025.06.13 15:43:23.155578 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 1, should be 2: In scope SELECT bitmapHasAny(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:23.304658 [ 5978 ] {461fe210-fb21-4d38-aebc-a9735b268044} executeQuery: Code: 43. DB::Exception: First argument for function bitmapMax must be a bitmap but it has type Int8.: In scope SELECT bitmapMax(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 306, line 307) (in query: SELECT bitmapMax(-1);) 2025.06.13 15:43:23.337950 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapMax must be a bitmap but it has type Int8.: In scope SELECT bitmapMax(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:23.564557 [ 5978 ] {20d14005-68eb-41ec-a85a-2059489ce7f5} executeQuery: Code: 43. DB::Exception: First argument for function bitmapMin must be a bitmap but it has type Int8.: In scope SELECT bitmapMin(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 307, line 308) (in query: SELECT bitmapMin(-1);) 2025.06.13 15:43:23.586455 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapMin must be a bitmap but it has type Int8.: In scope SELECT bitmapMin(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:23.641296 [ 5978 ] {fedea64d-b9b1-42a7-9845-39edde392acd} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 1, should be 2: In scope SELECT bitmapOr(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 308, line 309) (in query: SELECT bitmapOr(-1);) 2025.06.13 15:43:23.651528 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 1, should be 2: In scope SELECT bitmapOr(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:23.716567 [ 5978 ] {f6c1eb7d-bb9e-4efe-a374-f34194136d01} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapOrCardinality(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 309, line 310) (in query: SELECT bitmapOrCardinality(-1);) 2025.06.13 15:43:23.737243 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapOrCardinality(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:23.867239 [ 5978 ] {af690e59-f616-4780-b1c8-a2bfec45aa0d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 1, should be 3: In scope SELECT bitmapSubsetInRange(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 310, line 311) (in query: SELECT bitmapSubsetInRange(-1);) 2025.06.13 15:43:23.884395 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 1, should be 3: In scope SELECT bitmapSubsetInRange(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:24.000859 [ 8431 ] {1d98e9d0-4318-43a8-b414-da830dce09c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 0, should be 1: In scope SELECT emptyArrayToSingle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 509, line 510) (in query: SELECT emptyArrayToSingle();) 2025.06.13 15:43:24.002223 [ 5978 ] {909dbccb-1b59-4b9e-8322-85eae33ebef8} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 1, should be 3: In scope SELECT bitmapSubsetLimit(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 311, line 312) (in query: SELECT bitmapSubsetLimit(-1);) 2025.06.13 15:43:24.007894 [ 8442 ] {880881a8-cdb5-4cb6-a48b-2e3ffd0d0b60} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 2, should be 1: In scope SELECT sin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1218, line 1220) (in query: SELECT sin(NULL, NULL);) 2025.06.13 15:43:24.015277 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 0, should be 1: In scope SELECT emptyArrayToSingle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:24.023115 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 2, should be 1: In scope SELECT sin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:24.023060 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 1, should be 3: In scope SELECT bitmapSubsetLimit(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:24.132485 [ 7279 ] {61a23d14-c568-41a1-a01f-4338c243000a} executeQuery: Code: 36. DB::Exception: Expression in arrayJoin cannot depend on lambda argument: array(x, 1_UInt8) . (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40530) (comment: 01330_array_join_in_higher_order_function.sql) (query 1, line 1) (in query: SELECT arrayMap(x -> arrayJoin([x, 1]), [1, 2]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:1020: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb7cc94 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:795: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb79af1 7. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x000000002cb7072c 8. ./build_docker/./src/Planner/Utils.cpp:252: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000002cb8e964 9. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:377: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002ddfe1f7 10. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6eedb 11. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:43:24.138364 [ 7279 ] {} TCPHandler: Code: 36. DB::Exception: Expression in arrayJoin cannot depend on lambda argument: array(x, 1_UInt8) . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:1020: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb7cc94 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:795: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb79af1 7. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x000000002cb7072c 8. ./build_docker/./src/Planner/Utils.cpp:252: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000002cb8e964 9. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:377: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002ddfe1f7 10. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6eedb 11. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:43:24.194178 [ 5978 ] {a54f675d-e610-4052-897a-f5514a8561d4} executeQuery: Code: 43. DB::Exception: First argument for function bitmapToArray must be a bitmap but it has type Int8.: In scope SELECT bitmapToArray(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 312, line 313) (in query: SELECT bitmapToArray(-1);) 2025.06.13 15:43:24.198965 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapToArray must be a bitmap but it has type Int8.: In scope SELECT bitmapToArray(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:24.228536 [ 8442 ] {8b9694dd-bbf4-48f6-ac5d-661ab18e163f} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 2, should be 1: In scope SELECT sinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1220, line 1222) (in query: SELECT sinh(NULL, NULL);) 2025.06.13 15:43:24.235334 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 2, should be 1: In scope SELECT sinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:24.254672 [ 5978 ] {6f2ac976-7275-475c-bbdd-6a5d71f38c12} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 1, should be 3: In scope SELECT bitmapTransform(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 313, line 314) (in query: SELECT bitmapTransform(-1);) 2025.06.13 15:43:24.291145 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 1, should be 3: In scope SELECT bitmapTransform(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:24.387132 [ 5978 ] {f783d516-0cac-4dff-b722-a9b8110f731f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 1, should be 2: In scope SELECT bitmapXor(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 314, line 315) (in query: SELECT bitmapXor(-1);) 2025.06.13 15:43:24.400940 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 1, should be 2: In scope SELECT bitmapXor(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:24.446735 [ 5978 ] {58d5308a-dcbc-4c6d-8d1c-bce74174e0de} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapXorCardinality(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 315, line 316) (in query: SELECT bitmapXorCardinality(-1);) 2025.06.13 15:43:24.462743 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 1, should be 2: In scope SELECT bitmapXorCardinality(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:25.075340 [ 5978 ] {981504d2-0820-49d9-87de-85bc15314c9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 1, should be 0: In scope SELECT blockNumber(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 318, line 319) (in query: SELECT blockNumber(-1);) 2025.06.13 15:43:25.082767 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 1, should be 0: In scope SELECT blockNumber(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:25.244333 [ 8431 ] {5edd4dda-d469-47de-9c6d-adb71b46a83c} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 0, should be 1: In scope SELECT encodeURLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 516, line 517) (in query: SELECT encodeURLComponent();) 2025.06.13 15:43:25.268367 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 0, should be 1: In scope SELECT encodeURLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:25.372224 [ 8431 ] {9002fef3-bb32-4cd0-a2b9-1fb7c8632fb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 0, should be 1: In scope SELECT encodeURLFormComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 517, line 518) (in query: SELECT encodeURLFormComponent();) 2025.06.13 15:43:25.390761 [ 5978 ] {55b94a69-7f7f-4a3f-8d35-9c08fb038fa3} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 1, should be 0: In scope SELECT blockSize(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 320, line 321) (in query: SELECT blockSize(-1);) 2025.06.13 15:43:25.392694 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 0, should be 1: In scope SELECT encodeURLFormComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:25.397384 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 1, should be 0: In scope SELECT blockSize(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:25.468556 [ 8431 ] {3ea09136-1b03-4963-95f8-cd385e9dc56c} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 0, should be 1: In scope SELECT encodeXMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 518, line 519) (in query: SELECT encodeXMLComponent();) 2025.06.13 15:43:25.480345 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 0, should be 1: In scope SELECT encodeXMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:25.482666 [ 5978 ] {390b6ac2-c5c2-43cb-a9af-4f0d8ad3da1d} executeQuery: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 321, line 322) (in query: SELECT boundingRatio(-1);) 2025.06.13 15:43:25.500910 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:25.523736 [ 18377 ] {47772f8d-065b-45ca-a773-8739fc4f48bc} executeQuery: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59946) (comment: 02946_parallel_replicas_force_primary_key.sql) (query 16, line 38) (in query: SELECT `__table1`.`k` AS `k`, count() AS `count()` FROM `test_2kn3f1ep`.`t1` AS `__table1` GROUP BY `__table1`.`k` ORDER BY `__table1`.`k` ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:43:25.538014 [ 3895 ] {a1053491-cc50-4230-a016-2e46de251b0c} executeQuery: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53374) (comment: 02946_parallel_replicas_force_primary_key.sql) (query 16, line 38) (in query: SELECT `__table1`.`k` AS `k`, count() AS `count()` FROM `test_2kn3f1ep`.`t1` AS `__table1` GROUP BY `__table1`.`k` ORDER BY `__table1`.`k` ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:43:25.541386 [ 18377 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:43:25.544807 [ 3895 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:43:25.551371 [ 5112 ] {7d4573ec-8b34-4822-a171-cd44b68abe05} executeQuery: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59910) (comment: 02946_parallel_replicas_force_primary_key.sql) (query 16, line 38) (in query: SELECT `__table1`.`k` AS `k`, count() AS `count()` FROM `test_2kn3f1ep`.`t1` AS `__table1` GROUP BY `__table1`.`k` ORDER BY `__table1`.`k` ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:43:25.594763 [ 8431 ] {1a128110-c9a5-4e20-bb39-ae38457f72ac} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT encrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 519, line 520) (in query: SELECT encrypt();) 2025.06.13 15:43:25.599073 [ 5112 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:43:25.606165 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT encrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:25.608530 [ 5978 ] {613eb75d-5857-48b1-9073-0781c917619e} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 1, should be 0: In scope SELECT buildId(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 322, line 323) (in query: SELECT buildId(-1);) 2025.06.13 15:43:25.628889 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 1, should be 0: In scope SELECT buildId(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:25.676985 [ 3931 ] {f89ffa96-3553-46de-b77a-f03919014c15} executeQuery: Code: 277. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 : While executing Remote. (INDEX_NOT_USED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58374) (comment: 02946_parallel_replicas_force_primary_key.sql) (query 16, line 38) (in query: -- parallel replicas, primary key is NOT used SELECT k, count() FROM t1 GROUP BY k ORDER BY k SETTINGS force_primary_key = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:43:25.689628 [ 3931 ] {} TCPHandler: Code: 277. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000003043fb6f 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1754: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a4f5a 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 : While executing Remote. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:43:25.754031 [ 8431 ] {73a48f24-418f-4685-b289-9331793465f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 0, should be 2: In scope SELECT endsWith(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 520, line 521) (in query: SELECT endsWith();) 2025.06.13 15:43:25.785578 [ 5978 ] {c4b85ec9-0dcf-47e0-aee6-c812ead8916c} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 1, should be 2: In scope SELECT byteHammingDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 323, line 324) (in query: SELECT byteHammingDistance(-1);) 2025.06.13 15:43:25.785802 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 0, should be 2: In scope SELECT endsWith(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:25.811718 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 1, should be 2: In scope SELECT byteHammingDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:25.894535 [ 8431 ] {3545dbbe-77ba-4753-bc42-2bec356ea51c} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 0, should be 2: In scope SELECT endsWithUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 521, line 522) (in query: SELECT endsWithUTF8();) 2025.06.13 15:43:25.916171 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 0, should be 2: In scope SELECT endsWithUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:25.994709 [ 8431 ] {83def393-1b16-450a-8026-377d322a1643} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function entropy. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 522, line 523) (in query: SELECT entropy();) 2025.06.13 15:43:26.004815 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function entropy. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:26.120409 [ 5978 ] {f6380edb-ff56-46bb-b229-ad697feb7321} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 1, should be 2 or 3: In scope SELECT byteSlice(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 325, line 326) (in query: SELECT byteSlice(-1);) 2025.06.13 15:43:26.136526 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 1, should be 2 or 3: In scope SELECT byteSlice(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:26.147624 [ 8431 ] {13a818f9-d785-4be2-8d01-f91fc6999de8} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 0, should be 2: In scope SELECT equals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 523, line 524) (in query: SELECT equals();) 2025.06.13 15:43:26.158989 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 0, should be 2: In scope SELECT equals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:26.235860 [ 8431 ] {23579a4e-465e-4cc5-8855-ec9ba90be807} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 0, should be 1: In scope SELECT erf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 524, line 525) (in query: SELECT erf();) 2025.06.13 15:43:26.242466 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 0, should be 1: In scope SELECT erf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:26.262517 [ 8442 ] {d2428b3f-5beb-4311-91a9-3f62e3ef564d} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 2, should be 1: In scope SELECT sleep(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1229, line 1231) (in query: SELECT sleep(NULL, NULL);) 2025.06.13 15:43:26.273418 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 2, should be 1: In scope SELECT sleep(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:26.331245 [ 8432 ] {282ae512-73ac-4508-8060-3a42a41b361b} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40588) (comment: 03274_dynamic_column_data_race_with_concurrent_hj.sql) (query 4, line 4) (in query: CREATE TABLE t0 (c0 Tuple(c1 Int,c2 Dynamic)) ENGINE = Memory();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:26.347592 [ 8432 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:26.369241 [ 8442 ] {099ba270-e2cf-4c63-a602-87416e810349} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 2, should be 1: In scope SELECT sleepEachRow(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1230, line 1232) (in query: SELECT sleepEachRow(NULL, NULL);) 2025.06.13 15:43:26.389306 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 2, should be 1: In scope SELECT sleepEachRow(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:26.391118 [ 8431 ] {7213697c-2986-4ce6-8256-ce6e1f381ceb} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 0, should be 1: In scope SELECT erfc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 525, line 526) (in query: SELECT erfc();) 2025.06.13 15:43:26.401844 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 0, should be 1: In scope SELECT erfc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:26.470273 [ 8431 ] {ccf4c11c-e8d0-4e8a-8a13-f6fbe1a09e3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 0, should be 1: In scope SELECT errorCodeToName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 526, line 527) (in query: SELECT errorCodeToName();) 2025.06.13 15:43:26.484196 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 0, should be 1: In scope SELECT errorCodeToName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:26.561265 [ 8431 ] {9b648bdc-5eba-4605-9117-2125034dcc9b} executeQuery: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 527, line 528) (in query: SELECT estimateCompressionRatio();) 2025.06.13 15:43:26.566148 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:26.654086 [ 5978 ] {e08bcdfd-7a08-4b2e-bd9c-ab2422d70b65} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 329, line 330) (in query: SELECT caseWithoutExpr(-1);) 2025.06.13 15:43:26.694033 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:26.709759 [ 8431 ] {62191801-cf29-476e-a44d-1a92d64271cb} executeQuery: Code: 36. DB::Exception: Function evalMLMethod requires at least one argument: In scope SELECT evalMLMethod(). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 528, line 529) (in query: SELECT evalMLMethod();) 2025.06.13 15:43:26.719630 [ 8431 ] {} TCPHandler: Code: 36. DB::Exception: Function evalMLMethod requires at least one argument: In scope SELECT evalMLMethod(). (BAD_ARGUMENTS) 2025.06.13 15:43:26.782804 [ 5978 ] {330d2c20-9ccf-48bd-8d31-3dc69b8b64c1} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 330, line 331) (in query: SELECT caseWithoutExpression(-1);) 2025.06.13 15:43:26.789994 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:26.805832 [ 8431 ] {6f4bf6ed-a2d2-48f6-8d44-1de0f00c385d} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 0, should be 1: In scope SELECT exp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 529, line 530) (in query: SELECT exp();) 2025.06.13 15:43:26.825415 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 0, should be 1: In scope SELECT exp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:26.919033 [ 8431 ] {9e8973f2-340c-4636-9b28-c7b02b69c9aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 0, should be 1: In scope SELECT exp10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 530, line 531) (in query: SELECT exp10();) 2025.06.13 15:43:26.920855 [ 5110 ] {2251f1f1-4587-478e-aab9-012964e0646d} executeQuery: Code: 497. DB::Exception: u_02015_denied: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(id, s) ON test_piutasd2.async_inserts. (ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:54816) (comment: 02015_async_inserts_4.sh) (in query: INSERT INTO async_inserts FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd57d89 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd569b5 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002bd55ccc 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002bd178f0 8. ./src/Access/ContextAccess.h:259: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002d4bb3a0 9. ./build_docker/./src/Interpreters/Context.cpp:1762: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002d47c6a9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:362: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f5009 11. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:43:26.930994 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 0, should be 1: In scope SELECT exp10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:26.933481 [ 5110 ] {2251f1f1-4587-478e-aab9-012964e0646d} DynamicQueryHandler: Code: 497. DB::Exception: u_02015_denied: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(id, s) ON test_piutasd2.async_inserts. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd57d89 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002bd569b5 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002bd55ccc 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002bd178f0 8. ./src/Access/ContextAccess.h:259: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000002d4bb3a0 9. ./build_docker/./src/Interpreters/Context.cpp:1762: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x000000002d47c6a9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:362: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f5009 11. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:26.935614 [ 5978 ] {1a68a298-bf10-4ca7-8449-436cad0518f8} executeQuery: Code: 35. DB::Exception: Function catboostEvaluate expects at least 2 arguments: In scope SELECT catboostEvaluate(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 331, line 332) (in query: SELECT catboostEvaluate(-1);) 2025.06.13 15:43:26.945872 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: Function catboostEvaluate expects at least 2 arguments: In scope SELECT catboostEvaluate(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:43:27.014902 [ 8431 ] {e4e10cc9-58b6-4a86-b7bf-942ba9f98e6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 0, should be 1: In scope SELECT exp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 531, line 532) (in query: SELECT exp2();) 2025.06.13 15:43:27.028509 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 0, should be 1: In scope SELECT exp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:27.042530 [ 5978 ] {9c1242dd-52a7-492c-b45c-05c0acbb20a7} executeQuery: Code: 42. DB::Exception: Aggregate function categoricalInformationValue requires two or more arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 332, line 333) (in query: SELECT categoricalInformationValue(-1);) 2025.06.13 15:43:27.048416 [ 8442 ] {de941f3c-aaa1-4364-9d17-2abef1a893d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 2, should be 1: In scope SELECT soundex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1235, line 1237) (in query: SELECT soundex(NULL, NULL);) 2025.06.13 15:43:27.065869 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function categoricalInformationValue requires two or more arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:27.065900 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 2, should be 1: In scope SELECT soundex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:27.101380 [ 8431 ] {6eafcc9e-827c-41b1-8d13-7670f4c88ff2} executeQuery: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 532, line 533) (in query: SELECT exponentialMovingAverage();) 2025.06.13 15:43:27.110794 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:27.173600 [ 8442 ] {0948a5bd-32c5-4a3a-9b13-25230215f998} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 2, should be 1: In scope SELECT space(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1236, line 1238) (in query: SELECT space(NULL, NULL);) 2025.06.13 15:43:27.184975 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 2, should be 1: In scope SELECT space(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:27.196779 [ 8431 ] {edd31acf-e42c-4f15-9a7d-5974cf399878} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 533, line 534) (in query: SELECT exponentialTimeDecayedAvg();) 2025.06.13 15:43:27.211290 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:27.276075 [ 7279 ] {6ffa7b7a-87ef-4272-95de-d8c56f99e57e} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40652) (comment: 00938_dataset_test.sql) (query 2, line 2) (in query: CREATE TABLE IF NOT EXISTS defaults ( param1 Float64, param2 Float64, target Float64, predict1 Float64, predict2 Float64 ) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:27.288812 [ 7279 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:27.330600 [ 8431 ] {ab49c84f-72d4-4a46-926c-e851cb8cb0e1} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 534, line 535) (in query: SELECT exponentialTimeDecayedCount();) 2025.06.13 15:43:27.362230 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:27.453807 [ 8431 ] {21aa748e-0884-4341-a916-f313c6a14494} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 535, line 536) (in query: SELECT exponentialTimeDecayedMax();) 2025.06.13 15:43:27.470810 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:27.592631 [ 8431 ] {db01d142-9508-419b-a1df-fc978e5cb941} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 536, line 537) (in query: SELECT exponentialTimeDecayedSum();) 2025.06.13 15:43:27.604129 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:27.749524 [ 8431 ] {fbae48ad-e204-4c2f-8f6e-f35b7613f95e} executeQuery: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 0, should be 2: In scope SELECT extract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 537, line 538) (in query: SELECT extract();) 2025.06.13 15:43:27.752026 [ 5978 ] {8d88fc0c-0d7c-4f32-a3b1-3c28d0ca6469} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 1, should be 2: In scope SELECT changeDay(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 336, line 337) (in query: SELECT changeDay(-1);) 2025.06.13 15:43:27.772649 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 0, should be 2: In scope SELECT extract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:27.774148 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 1, should be 2: In scope SELECT changeDay(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:27.884737 [ 8431 ] {aa4d40b3-1375-4721-b5db-de527605e70a} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 0, should be 2: In scope SELECT extractAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 538, line 539) (in query: SELECT extractAll();) 2025.06.13 15:43:27.893287 [ 5978 ] {60e0e00e-433a-431a-a037-9369f81c74e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 1, should be 2: In scope SELECT changeHour(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 337, line 338) (in query: SELECT changeHour(-1);) 2025.06.13 15:43:27.903001 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 1, should be 2: In scope SELECT changeHour(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:27.903004 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 0, should be 2: In scope SELECT extractAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:28.021490 [ 5978 ] {d32b3f7c-5b1d-43a3-b894-87bae1e27213} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 1, should be 2: In scope SELECT changeMinute(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 338, line 339) (in query: SELECT changeMinute(-1);) 2025.06.13 15:43:28.034149 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 1, should be 2: In scope SELECT changeMinute(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:28.047296 [ 8431 ] {9ace33b9-b48a-4974-858e-5b99646bcd88} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 0, should be 2: In scope SELECT extractAllGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 539, line 540) (in query: SELECT extractAllGroups();) 2025.06.13 15:43:28.081495 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 0, should be 2: In scope SELECT extractAllGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:28.123939 [ 5978 ] {2039a924-2c32-4390-a595-c0040e7ce7ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 1, should be 2: In scope SELECT changeMonth(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 339, line 340) (in query: SELECT changeMonth(-1);) 2025.06.13 15:43:28.134486 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 1, should be 2: In scope SELECT changeMonth(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:28.188086 [ 8431 ] {2a3c0a68-9c2d-4cde-a384-5129f24f62b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsHorizontal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 540, line 541) (in query: SELECT extractAllGroupsHorizontal();) 2025.06.13 15:43:28.197913 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsHorizontal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:28.223880 [ 5978 ] {b9d73e56-917e-493b-8cc6-94a9dd9af507} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 1, should be 2: In scope SELECT changeSecond(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 340, line 341) (in query: SELECT changeSecond(-1);) 2025.06.13 15:43:28.257900 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 1, should be 2: In scope SELECT changeSecond(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:28.327927 [ 8431 ] {25d59b47-d8fe-41e2-99f0-27cd41edb392} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsVertical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 541, line 542) (in query: SELECT extractAllGroupsVertical();) 2025.06.13 15:43:28.348036 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsVertical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:28.431688 [ 5978 ] {76233ec3-bc7f-47e7-8670-996713971206} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 1, should be 2: In scope SELECT changeYear(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 341, line 342) (in query: SELECT changeYear(-1);) 2025.06.13 15:43:28.437411 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 1, should be 2: In scope SELECT changeYear(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:28.446831 [ 8431 ] {993a498c-bb14-4182-8ae7-bbde9f08514e} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 0, should be 2: In scope SELECT extractGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 542, line 543) (in query: SELECT extractGroups();) 2025.06.13 15:43:28.463929 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 0, should be 2: In scope SELECT extractGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:28.541631 [ 8431 ] {982c0142-cb45-4275-8586-c550be719d30} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT extractKeyValuePairs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 543, line 544) (in query: SELECT extractKeyValuePairs();) 2025.06.13 15:43:28.558718 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT extractKeyValuePairs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:28.653378 [ 8431 ] {7e28b643-93c6-4fe8-96c8-32cfbbe448c1} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT extractKeyValuePairsWithEscaping(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 544, line 545) (in query: SELECT extractKeyValuePairsWithEscaping();) 2025.06.13 15:43:28.668303 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT extractKeyValuePairsWithEscaping(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:28.739205 [ 8431 ] {5290b50e-1cb8-4792-b8c1-ce9ae83198f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 0, should be 1: In scope SELECT extractTextFromHTML(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 545, line 546) (in query: SELECT extractTextFromHTML();) 2025.06.13 15:43:28.746600 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 0, should be 1: In scope SELECT extractTextFromHTML(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:28.911192 [ 5978 ] {54ca1ead-8593-4650-9e38-baf3b53752cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 1, should be 3: In scope SELECT clamp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 344, line 345) (in query: SELECT clamp(-1);) 2025.06.13 15:43:28.916076 [ 8431 ] {7356b963-844e-4497-b2c4-2f56f159ad27} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 0, should be 2: In scope SELECT extractURLParameter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 546, line 547) (in query: SELECT extractURLParameter();) 2025.06.13 15:43:28.920155 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 1, should be 3: In scope SELECT clamp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:28.922910 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 0, should be 2: In scope SELECT extractURLParameter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:29.027355 [ 8431 ] {34dbb5e6-a3fd-49d4-9d44-d919a19def08} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 0, should be 1: In scope SELECT extractURLParameterNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 547, line 548) (in query: SELECT extractURLParameterNames();) 2025.06.13 15:43:29.034998 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 0, should be 1: In scope SELECT extractURLParameterNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:29.036001 [ 8442 ] {f18d49b9-bfe8-43be-87ac-8e608d3a4bca} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 2, should be 1: In scope SELECT sqidDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1246, line 1248) (in query: SELECT sqidDecode(NULL, NULL);) 2025.06.13 15:43:29.046724 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 2, should be 1: In scope SELECT sqidDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:29.138331 [ 8431 ] {901c0e06-d4df-4df5-8d2a-26b1c96b119e} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 0, should be 1: In scope SELECT extractURLParameters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 548, line 549) (in query: SELECT extractURLParameters();) 2025.06.13 15:43:29.144567 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 0, should be 1: In scope SELECT extractURLParameters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:29.254321 [ 5978 ] {d51afdb9-df87-4732-aa41-acc68651ed94} 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(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 346, line 347) (in query: SELECT compareSubstrings(-1);) 2025.06.13 15:43:29.258491 [ 5978 ] {} 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(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:29.293858 [ 8431 ] {4bb8ae31-d125-4fe9-bdad-dc7af2763b90} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 0, should be 1: In scope SELECT factorial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 549, line 550) (in query: SELECT factorial();) 2025.06.13 15:43:29.313263 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 0, should be 1: In scope SELECT factorial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:29.316233 [ 5005 ] {6625640d-ec9b-42f0-a0a0-864901e6797a} executeQuery: Code: 507. DB::Exception: Sharding key key is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40684) (comment: 01211_optimize_skip_unused_shards_type_mismatch.sql) (query 7, line 12) (in query: select * from dist_02000 where key = 0xdeadbeafdeadbeaf settings force_optimize_skip_unused_shards=2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003038b83b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030389607 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda0ed6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:43:29.332807 [ 5005 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key key is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1563: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003038b83b 6. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000030389607 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dda0ed6 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 9. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 10. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:43:29.461164 [ 8442 ] {8e0ca8eb-fa16-4485-b5ed-ffe65a749b82} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 2, should be 1: In scope SELECT sqrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1248, line 1250) (in query: SELECT sqrt(NULL, NULL);) 2025.06.13 15:43:29.467669 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 2, should be 1: In scope SELECT sqrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:29.642397 [ 5978 ] {5a31ce2e-bce2-4e8a-a38d-acaebe009133} executeQuery: Code: 35. DB::Exception: Number of arguments for function concatAssumeInjective should not be 1: In scope SELECT concatAssumeInjective(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 348, line 349) (in query: SELECT concatAssumeInjective(-1);) 2025.06.13 15:43:29.662523 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function concatAssumeInjective should not be 1: In scope SELECT concatAssumeInjective(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:43:29.835194 [ 5978 ] {b1888253-ca61-4a6c-a555-b54d477c824f} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function concatWithSeparator: In scope SELECT concatWithSeparator(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 349, line 350) (in query: SELECT concatWithSeparator(-1);) 2025.06.13 15:43:29.847183 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function concatWithSeparator: In scope SELECT concatWithSeparator(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:29.907366 [ 8431 ] {596fba26-d5c6-4453-9de0-9dc54817031e} executeQuery: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 0, should be 1 or 2: In scope SELECT file(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 552, line 553) (in query: SELECT file();) 2025.06.13 15:43:29.922922 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 0, should be 1 or 2: In scope SELECT file(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:30.017642 [ 5978 ] {5ac0092b-3e42-4863-8665-aaa3c73000dd} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function concatWithSeparatorAssumeInjective: In scope SELECT concatWithSeparatorAssumeInjective(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 350, line 351) (in query: SELECT concatWithSeparatorAssumeInjective(-1);) 2025.06.13 15:43:30.018213 [ 5110 ] {} DynamicQueryHandler: Code: 744. DB::Exception: Session id query parameter was provided, but it was empty. (SESSION_ID_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/HTTPHandler.cpp:244: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b2d1f 6. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 7. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:30.031939 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function concatWithSeparatorAssumeInjective: In scope SELECT concatWithSeparatorAssumeInjective(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:30.084847 [ 2860 ] {test_01948_tcp_test_3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40710) (comment: 01950_kill_large_group_by_query.sh) (query 1, line 1) (in query: SELECT * FROM ( SELECT a.name as n FROM ( SELECT 'Name' as name, number FROM system.numbers LIMIT 2000000 ) AS a, ( SELECT 'Name' as name2, number FROM system.numbers LIMIT 2000000 ) as b GROUP BY n ) LIMIT 20 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002dee820f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002dee8126 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee88f7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:43:30.114237 [ 2860 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002dee820f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002dee8126 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee88f7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:43:30.132865 [ 5978 ] {d8c75279-6820-4ff7-bc19-11248159b6c0} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function concatWithSeparator: In scope SELECT concat_ws(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 351, line 352) (in query: SELECT concat_ws(-1);) 2025.06.13 15:43:30.138825 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function concatWithSeparator: In scope SELECT concat_ws(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:30.308229 [ 5978 ] {6827cf9d-0744-4515-9f1e-2f1d7ca90476} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 1, should be 0: In scope SELECT connectionId(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 352, line 353) (in query: SELECT connectionId(-1);) 2025.06.13 15:43:30.331454 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 1, should be 0: In scope SELECT connectionId(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:30.464045 [ 5978 ] {3bc53f25-cdfa-47ae-a7ee-765d1b12a5cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 1, should be 0: In scope SELECT connection_id(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 353, line 354) (in query: SELECT connection_id(-1);) 2025.06.13 15:43:30.481893 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 1, should be 0: In scope SELECT connection_id(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:30.612308 [ 5978 ] {04c6af5b-6d7e-4f1d-95f6-a2d6801b7e2e} executeQuery: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 354, line 355) (in query: SELECT contingency(-1);) 2025.06.13 15:43:30.636633 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:30.703244 [ 8431 ] {6ef0779e-8b2b-4e11-b490-b166e6cb9189} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 0, should be 1: In scope SELECT finalizeAggregation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 556, line 557) (in query: SELECT finalizeAggregation();) 2025.06.13 15:43:30.712581 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 0, should be 1: In scope SELECT finalizeAggregation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:30.838495 [ 5978 ] {2bb92ac1-64c8-478b-8cbc-92216d863b08} executeQuery: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 1, should be 3: In scope SELECT convertCharset(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 355, line 356) (in query: SELECT convertCharset(-1);) 2025.06.13 15:43:30.847236 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 1, should be 3: In scope SELECT convertCharset(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:30.849961 [ 8431 ] {dc9230cd-499d-45a6-8629-0fa289efaa64} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 0, should be 1: In scope SELECT firstLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 557, line 558) (in query: SELECT firstLine();) 2025.06.13 15:43:30.876426 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 0, should be 1: In scope SELECT firstLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:30.970218 [ 8442 ] {32d30768-c712-4664-83b9-b2ed0e7fc9ed} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1255, line 1257) (in query: SELECT stem(NULL, NULL);) 2025.06.13 15:43:30.998946 [ 8442 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:43:31.003833 [ 8431 ] {63c98362-b559-4758-b838-354fc1081dc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 0, should be 1: In scope SELECT firstSignificantSubdomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 558, line 559) (in query: SELECT firstSignificantSubdomain();) 2025.06.13 15:43:31.021433 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 0, should be 1: In scope SELECT firstSignificantSubdomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:31.042348 [ 5978 ] {808579a1-ea80-43cd-b8b2-ec1e6999f954} executeQuery: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 356, line 357) (in query: SELECT corr(-1);) 2025.06.13 15:43:31.049759 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:31.154614 [ 8431 ] {3c01afb3-812e-4ffe-9aa8-4bfdeed1042d} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 0, should be 2: In scope SELECT firstSignificantSubdomainCustom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 559, line 560) (in query: SELECT firstSignificantSubdomainCustom();) 2025.06.13 15:43:31.167913 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 0, should be 2: In scope SELECT firstSignificantSubdomainCustom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:31.240521 [ 8431 ] {408baba1-93a3-44ed-b183-3fe39ea6bd07} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 0, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 560, line 561) (in query: SELECT firstSignificantSubdomainCustomRFC();) 2025.06.13 15:43:31.249757 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 0, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:31.301752 [ 18510 ] {test_01948_http_test_3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:54844) (comment: 01950_kill_large_group_by_query.sh) (in query: SELECT * FROM ( SELECT a.name as n FROM ( SELECT 'Name' as name, number FROM system.numbers LIMIT 2000000 ) AS a, ( SELECT 'Name' as name2, number FROM system.numbers LIMIT 2000000 ) as b GROUP BY n ) LIMIT 20 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002dee820f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002dee8126 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee88f7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:43:31.304764 [ 5978 ] {22b9cb9e-637d-4871-9e4e-ff540fc59aa9} executeQuery: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 358, line 359) (in query: SELECT corrStable(-1);) 2025.06.13 15:43:31.305144 [ 18510 ] {test_01948_http_test_3} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002dee820f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002dee8126 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee88f7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:31.312221 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:31.315568 [ 8431 ] {a0fcdd35-c81a-4b9e-9225-fabe865c6f28} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 0, should be 1: In scope SELECT firstSignificantSubdomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 561, line 562) (in query: SELECT firstSignificantSubdomainRFC();) 2025.06.13 15:43:31.321229 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 0, should be 1: In scope SELECT firstSignificantSubdomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:31.364898 [ 8431 ] {a67a4220-5678-42a8-b748-873d894bb38a} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 562, line 563) (in query: SELECT firstValueRespectNulls();) 2025.06.13 15:43:31.376994 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:31.423072 [ 8431 ] {6282b091-c15e-4508-a66d-38dfc5023b50} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 563, line 564) (in query: SELECT first_value();) 2025.06.13 15:43:31.429698 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:31.492317 [ 8431 ] {022323c0-a6e9-4a82-847e-5510bc0d902a} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 564, line 565) (in query: SELECT first_value_respect_nulls();) 2025.06.13 15:43:31.502563 [ 9644 ] {7e82be14-1d80-4cc8-a93e-f86225465342} executeQuery: Code: 36. DB::Exception: Engine Distributed doesn't support skipping indices. Currently only the following engines have support for the feature: [ReplicatedSummingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, ReplicatedMergeTree, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, ReplicatedReplacingMergeTree, SummingMergeTree, MergeTree, GraphiteMergeTree, CollapsingMergeTree, ReplicatedAggregatingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40778) (comment: 01011_test_create_as_skip_indices.sql) (query 3, line 3) (in query: CREATE TABLE dist (key int, INDEX i1 key TYPE minmax GRANULARITY 1) Engine=Distributed(test_shard_localhost, currentDatabase(), 'foo');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x0000000023f0614f 5. ./build_docker/./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 @ 0x00000000303cc2e7 6. ./build_docker/./src/Storages/StorageFactory.cpp:209: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000303cab0f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:31.508977 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:31.512923 [ 9644 ] {} TCPHandler: Code: 36. DB::Exception: Engine Distributed doesn't support skipping indices. Currently only the following engines have support for the feature: [ReplicatedSummingMergeTree, ReplicatedVersionedCollapsingMergeTree, VersionedCollapsingMergeTree, ReplacingMergeTree, ReplicatedMergeTree, ReplicatedCollapsingMergeTree, ReplicatedGraphiteMergeTree, ReplicatedReplacingMergeTree, SummingMergeTree, MergeTree, GraphiteMergeTree, CollapsingMergeTree, ReplicatedAggregatingMergeTree, AggregatingMergeTree]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&) @ 0x0000000023f0614f 5. ./build_docker/./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 @ 0x00000000303cc2e7 6. ./build_docker/./src/Storages/StorageFactory.cpp:209: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000303cab0f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:31.571916 [ 5978 ] {674a26b7-704f-47aa-9dc0-7b824366fbdb} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 1, should be 2: In scope SELECT cosineDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 361, line 362) (in query: SELECT cosineDistance(-1);) 2025.06.13 15:43:31.600737 [ 8431 ] {75f7fe80-82e4-4a7b-aaad-7caf6f3a4fa8} executeQuery: Code: 42. DB::Exception: Aggregate function flameGraph requires 1 to 3 arguments : trace, [size = 1], [ptr = 0]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 565, line 566) (in query: SELECT flameGraph();) 2025.06.13 15:43:31.608563 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 1, should be 2: In scope SELECT cosineDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:31.631062 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function flameGraph requires 1 to 3 arguments : trace, [size = 1], [ptr = 0]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:31.739380 [ 8431 ] {0ade30b0-ed74-47a6-878e-93cdd469c664} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 0, should be 1: In scope SELECT flatten(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 566, line 567) (in query: SELECT flatten();) 2025.06.13 15:43:31.753629 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 0, should be 1: In scope SELECT flatten(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:31.903015 [ 8431 ] {731fe5b4-3622-4416-bff8-601b9b118ec7} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 0, should be 1: In scope SELECT flattenTuple(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 567, line 568) (in query: SELECT flattenTuple();) 2025.06.13 15:43:31.912465 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 0, should be 1: In scope SELECT flattenTuple(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.002547 [ 8431 ] {dce483f8-a5e5-4aa8-ae2a-d4ec6e5d8ee0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'floor'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT floor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 568, line 569) (in query: SELECT floor();) 2025.06.13 15:43:32.008451 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'floor'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT floor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.081349 [ 8431 ] {2daf2503-9772-4e8d-bbf6-c18984b84124} executeQuery: Code: 42. DB::Exception: Number of arguments for function format doesn't match: passed 0, should be at least 2: In scope SELECT format(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 569, line 570) (in query: SELECT format();) 2025.06.13 15:43:32.085720 [ 8442 ] {bf82ec8b-26e2-49e8-8389-9d1d18f6d501} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 2, should be 1: In scope SELECT stringToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1262, line 1264) (in query: SELECT stringToH3(NULL, NULL);) 2025.06.13 15:43:32.088045 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function format doesn't match: passed 0, should be at least 2: In scope SELECT format(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.095204 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 2, should be 1: In scope SELECT stringToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.099668 [ 5978 ] {1762dca7-73f3-4c5a-b598-5e0289f7edea} executeQuery: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 1, should be 2: In scope SELECT countEqual(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 364, line 365) (in query: SELECT countEqual(-1);) 2025.06.13 15:43:32.116194 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 1, should be 2: In scope SELECT countEqual(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.243626 [ 8442 ] {825be754-660e-4c0b-afe9-d1968aedd0d9} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToCapnProtoSchema, expected constant string: In scope SELECT structureToCapnProtoSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1263, line 1265) (in query: SELECT structureToCapnProtoSchema(NULL, NULL);) 2025.06.13 15:43:32.246044 [ 8431 ] {2b19542a-934f-4037-b770-cdc7f2c77549} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 570, line 571) (in query: SELECT formatDateTime();) 2025.06.13 15:43:32.256952 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToCapnProtoSchema, expected constant string: In scope SELECT structureToCapnProtoSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:32.258557 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.284803 [ 5978 ] {0f5d1772-7fd5-457e-bedc-ebcf2c8bae75} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 1, should be 2: In scope SELECT countMatches(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 365, line 366) (in query: SELECT countMatches(-1);) 2025.06.13 15:43:32.298517 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 1, should be 2: In scope SELECT countMatches(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.376628 [ 8431 ] {d0fe5633-e030-4dd8-8a8b-988374884afb} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTimeInJodaSyntax doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTimeInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 571, line 572) (in query: SELECT formatDateTimeInJodaSyntax();) 2025.06.13 15:43:32.394510 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTimeInJodaSyntax doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTimeInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.394537 [ 8442 ] {e308e9dd-4212-4c2a-9fd5-e173fdaf6411} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToProtobufSchema, expected constant string: In scope SELECT structureToProtobufSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1264, line 1266) (in query: SELECT structureToProtobufSchema(NULL, NULL);) 2025.06.13 15:43:32.410175 [ 5978 ] {7bcdb3e3-13a7-4b82-9e5d-4c90be410a23} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT countMatchesCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 366, line 367) (in query: SELECT countMatchesCaseInsensitive(-1);) 2025.06.13 15:43:32.427857 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT countMatchesCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.430071 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToProtobufSchema, expected constant string: In scope SELECT structureToProtobufSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:32.475698 [ 8431 ] {2dacd6b1-839e-4e85-ba00-4efe095f82d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 0, should be 1: In scope SELECT formatQuery(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 572, line 573) (in query: SELECT formatQuery();) 2025.06.13 15:43:32.506215 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 0, should be 1: In scope SELECT formatQuery(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.602106 [ 5978 ] {a3c86618-67ba-4780-919e-9c2215a7881e} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstrings doesn't match: passed 1, should be 2 or 3: In scope SELECT countSubstrings(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 367, line 368) (in query: SELECT countSubstrings(-1);) 2025.06.13 15:43:32.619210 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstrings doesn't match: passed 1, should be 2 or 3: In scope SELECT countSubstrings(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.672459 [ 8431 ] {a2bb8854-46c8-4fd3-ba66-96dcf14cd48e} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 0, should be 1: In scope SELECT formatQueryOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 573, line 574) (in query: SELECT formatQueryOrNull();) 2025.06.13 15:43:32.691777 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 0, should be 1: In scope SELECT formatQueryOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.693969 [ 5978 ] {fe509752-0194-4bfe-b7a6-dce2bc19b86d} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitive doesn't match: passed 1, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 368, line 369) (in query: SELECT countSubstringsCaseInsensitive(-1);) 2025.06.13 15:43:32.708770 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitive doesn't match: passed 1, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.820490 [ 8431 ] {7a541741-0a9c-4041-8a86-6f64005b1139} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 0, should be 1: In scope SELECT formatQuerySingleLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 574, line 575) (in query: SELECT formatQuerySingleLine();) 2025.06.13 15:43:32.834832 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 0, should be 1: In scope SELECT formatQuerySingleLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.843543 [ 8442 ] {0adbc6d9-71a7-4d7d-86b6-5ba413c73eb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 2, should be 3: In scope SELECT subBitmap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1266, line 1268) (in query: SELECT subBitmap(NULL, NULL);) 2025.06.13 15:43:32.861674 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 2, should be 3: In scope SELECT subBitmap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.878750 [ 5978 ] {af40c472-2e89-4b5f-bb82-3b8a2fc90e69} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitiveUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 369, line 370) (in query: SELECT countSubstringsCaseInsensitiveUTF8(-1);) 2025.06.13 15:43:32.904581 [ 8431 ] {9917ea76-5bc1-48d7-bd94-b947737ecd30} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 0, should be 1: In scope SELECT formatQuerySingleLineOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 575, line 576) (in query: SELECT formatQuerySingleLineOrNull();) 2025.06.13 15:43:32.926802 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitiveUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:32.935057 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 0, should be 1: In scope SELECT formatQuerySingleLineOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:33.103122 [ 5978 ] {58553e52-ebce-42b0-a715-a45055d4ac15} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 370, line 371) (in query: SELECT covarPop(-1);) 2025.06.13 15:43:33.113999 [ 8431 ] {a65716df-e11a-43a9-897a-3b9bd7adddad} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 0, should be 1: In scope SELECT formatReadableDecimalSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 576, line 577) (in query: SELECT formatReadableDecimalSize();) 2025.06.13 15:43:33.119026 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:33.123344 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 0, should be 1: In scope SELECT formatReadableDecimalSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:33.296273 [ 8431 ] {6bbf2d26-9d21-40fd-b7d3-b5ceea545170} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 0, should be 1: In scope SELECT formatReadableQuantity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 577, line 578) (in query: SELECT formatReadableQuantity();) 2025.06.13 15:43:33.316194 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 0, should be 1: In scope SELECT formatReadableQuantity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:33.658371 [ 8431 ] {0f610d4d-b4b1-4cc6-882e-a9dd0254298b} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 0, should be 1: In scope SELECT formatReadableSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 578, line 579) (in query: SELECT formatReadableSize();) 2025.06.13 15:43:33.667962 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 0, should be 1: In scope SELECT formatReadableSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:33.754715 [ 5978 ] {4708c01a-7d91-4b4c-871a-ce835f9b6b4b} executeQuery: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 372, line 373) (in query: SELECT covarPopStable(-1);) 2025.06.13 15:43:33.774457 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:33.780331 [ 9642 ] {8eb38172-705b-45cb-aad0-05171fd1ad60} 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.20286.altinityantalya (altinity build)) (from [::1]:40554) (comment: 00101_materialized_views_and_insert_without_explicit_database.sql) (query 40, line 55) (in query: DROP DATABASE test_9), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:448: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcab9c2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:43:33.788422 [ 8442 ] {33e8d997-6ea1-40c0-a422-595d5b6a57b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT substringIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1270, line 1272) (in query: SELECT substringIndex(NULL, NULL);) 2025.06.13 15:43:33.811247 [ 8431 ] {c1a5ab1b-46b6-4e80-a309-66f1a8e4afc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableTimeDelta doesn't match: passed 0, should be at least 1.: In scope SELECT formatReadableTimeDelta(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 579, line 580) (in query: SELECT formatReadableTimeDelta();) 2025.06.13 15:43:33.814018 [ 9642 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:448: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcab9c2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:43:33.818310 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT substringIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:33.824769 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableTimeDelta doesn't match: passed 0, should be at least 1.: In scope SELECT formatReadableTimeDelta(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:33.889178 [ 5978 ] {f4f2b744-685d-474d-bb28-afa7021b9e19} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 373, line 374) (in query: SELECT covarSamp(-1);) 2025.06.13 15:43:33.956195 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:33.990240 [ 8442 ] {62785a33-60a8-4be2-a428-6cb527380644} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 2, should be 3: In scope SELECT substringIndexUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1271, line 1273) (in query: SELECT substringIndexUTF8(NULL, NULL);) 2025.06.13 15:43:34.011045 [ 8431 ] {dc473dd4-7178-4918-834e-d578cc37f00e} executeQuery: Code: 42. DB::Exception: Function formatRow requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 580, line 581) (in query: SELECT formatRow();) 2025.06.13 15:43:34.017174 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 2, should be 3: In scope SELECT substringIndexUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:34.033308 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function formatRow requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:34.207700 [ 8431 ] {c735a6f0-abc5-4d9a-a854-ac4617bd118d} executeQuery: Code: 42. DB::Exception: Function formatRowNoNewline requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRowNoNewline(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 581, line 582) (in query: SELECT formatRowNoNewline();) 2025.06.13 15:43:34.216332 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function formatRowNoNewline requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRowNoNewline(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:34.308209 [ 8431 ] {3aafb180-481a-4646-bd18-08cd3a328cf4} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 0, should be 1: In scope SELECT fragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 582, line 583) (in query: SELECT fragment();) 2025.06.13 15:43:34.327716 [ 5978 ] {7a81b99e-c521-497b-8e4e-d4871cb570ea} executeQuery: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 375, line 376) (in query: SELECT covarSampStable(-1);) 2025.06.13 15:43:34.329743 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 0, should be 1: In scope SELECT fragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:34.348332 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:34.423598 [ 8431 ] {d2d5974e-97bd-4a78-bac5-a79d99bfb4fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 0, should be 1: In scope SELECT fromDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 583, line 584) (in query: SELECT fromDaysSinceYearZero();) 2025.06.13 15:43:34.441209 [ 5978 ] {a3ff74c3-e194-4247-a912-8945c5b12749} executeQuery: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 376, line 377) (in query: SELECT cramersV(-1);) 2025.06.13 15:43:34.452467 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 0, should be 1: In scope SELECT fromDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:34.466597 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:34.607320 [ 8431 ] {ec5d0dff-14d2-41e2-88ce-56b479985a35} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 0, should be 1: In scope SELECT fromDaysSinceYearZero32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 584, line 585) (in query: SELECT fromDaysSinceYearZero32();) 2025.06.13 15:43:34.615373 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 0, should be 1: In scope SELECT fromDaysSinceYearZero32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:34.634643 [ 5978 ] {26a590cc-388e-4217-9f13-125e31f7400a} executeQuery: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 377, line 378) (in query: SELECT cramersVBiasCorrected(-1);) 2025.06.13 15:43:34.705160 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:34.740758 [ 8431 ] {2e5b1bf7-a30a-4b4c-acb9-7c73bd6f5e65} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 0, should be 1: In scope SELECT fromModifiedJulianDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 585, line 586) (in query: SELECT fromModifiedJulianDay();) 2025.06.13 15:43:34.760399 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 0, should be 1: In scope SELECT fromModifiedJulianDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:34.896426 [ 8431 ] {6b36b8a4-a5b6-4bb1-8a21-fff52e323563} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 0, should be 1: In scope SELECT fromModifiedJulianDayOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 586, line 587) (in query: SELECT fromModifiedJulianDayOrNull();) 2025.06.13 15:43:34.910237 [ 5978 ] {b4547f58-d4fe-4ffb-a2a5-fe7d334bb5e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 1, should be 0: In scope SELECT curdate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 378, line 379) (in query: SELECT curdate(-1);) 2025.06.13 15:43:34.926815 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 0, should be 1: In scope SELECT fromModifiedJulianDayOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:34.933384 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 1, should be 0: In scope SELECT curdate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:35.012060 [ 8431 ] {631fd32c-e768-4398-824a-e65b98c72a23} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT fromUTCTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 587, line 588) (in query: SELECT fromUTCTimestamp();) 2025.06.13 15:43:35.024239 [ 5978 ] {8e46608b-da12-4681-a28c-a14f608d7a6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT currentDatabase(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 379, line 380) (in query: SELECT currentDatabase(-1);) 2025.06.13 15:43:35.028014 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT fromUTCTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:35.037957 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT currentDatabase(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:35.120189 [ 3509 ] {8e29be3b-4f6a-4436-8143-90d220720df5::20191002_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/8e2/8e29be3b-4f6a-4436-8143-90d220720df5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:35.126129 [ 3509 ] {8e29be3b-4f6a-4436-8143-90d220720df5::20191002_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/8e2/8e29be3b-4f6a-4436-8143-90d220720df5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./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*) @ 0x000000002b0a61c0 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f608 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ab8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 23. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2cc3e5 24. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:308: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000030f336af 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000030f451f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f74818 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000030f63ea2 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:35.134633 [ 3509 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8e29be3b-4f6a-4436-8143-90d220720df5::20191002_2_2_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/8e2/8e29be3b-4f6a-4436-8143-90d220720df5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./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*) @ 0x000000002b0a61c0 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f608 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ab8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 23. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2cc3e5 24. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:308: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000030f336af 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000030f451f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f74818 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000030f63ea2 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:35.185741 [ 8431 ] {3bb576b6-b9ff-44eb-8f5e-01d02f034ae8} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestamp doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT fromUnixTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 588, line 589) (in query: SELECT fromUnixTimestamp();) 2025.06.13 15:43:35.198387 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestamp doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT fromUnixTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:35.203987 [ 9636 ] {baf83627-9e6c-41b1-88b4-f4a8a5651b1b} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20191002_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/8e2/8e29be3b-4f6a-4436-8143-90d220720df5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:464: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000311cd359 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 . (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01414_mutations_and_errors.sql) (in query: /* ddl_entry=query-0000000003 */ ALTER TABLE test_t7uy8er9.mutation_table (MODIFY COLUMN `value` UInt64) SETTINGS mutations_sync = 2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:464: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000311cd359 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:43:35.209005 [ 5978 ] {1c8481c1-bbba-4258-834d-3600ca0a0862} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 1, should be 0: In scope SELECT currentProfiles(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 380, line 381) (in query: SELECT currentProfiles(-1);) 2025.06.13 15:43:35.218475 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 1, should be 0: In scope SELECT currentProfiles(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:35.245959 [ 9636 ] {baf83627-9e6c-41b1-88b4-f4a8a5651b1b} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20191002_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/8e2/8e29be3b-4f6a-4436-8143-90d220720df5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:464: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000311cd359 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 . (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40796) (comment: 01414_mutations_and_errors.sql) (query 6, line 19) (in query: ALTER TABLE mutation_table MODIFY COLUMN value UInt64 SETTINGS mutations_sync = 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:464: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000311cd359 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:43:35.272959 [ 9636 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20191002_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/8e2/8e29be3b-4f6a-4436-8143-90d220720df5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:464: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000311cd359 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:464: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000311cd359 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:43:35.360173 [ 8431 ] {bb924dac-272d-400d-a5c9-f9784b814bd6} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Micro takes one or two arguments: In scope SELECT fromUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 589, line 590) (in query: SELECT fromUnixTimestamp64Micro();) 2025.06.13 15:43:35.368027 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Micro takes one or two arguments: In scope SELECT fromUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:35.379108 [ 5978 ] {f271ea48-eead-4071-9039-b56ded15f725} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 1, should be 0: In scope SELECT currentQueryID(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 381, line 382) (in query: SELECT currentQueryID(-1);) 2025.06.13 15:43:35.400979 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 1, should be 0: In scope SELECT currentQueryID(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:35.445818 [ 8431 ] {f47cd639-85e6-4b37-9ab7-915c8bb6549b} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Milli takes one or two arguments: In scope SELECT fromUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 590, line 591) (in query: SELECT fromUnixTimestamp64Milli();) 2025.06.13 15:43:35.456074 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Milli takes one or two arguments: In scope SELECT fromUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:35.487464 [ 9636 ] {012bb772-4983-43ae-96ae-05cee37bc3f6} executeQuery: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/8e2/8e29be3b-4f6a-4436-8143-90d220720df5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40796) (comment: 01414_mutations_and_errors.sql) (query 7, line 21) (in query: SELECT distinct(value) FROM mutation_table ORDER BY value;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./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*) @ 0x000000002b0a61c0 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f608 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ab8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 23. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2cc3e5 24. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:308: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000030f336af 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000030f451f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f74818 27. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 28. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 31. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 2025.06.13 15:43:35.500056 [ 9636 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 0, 'UInt64' :: 1) -> _CAST(value, 'UInt64') UInt64 : 2': (while reading from part /var/lib/clickhouse/store/8e2/8e29be3b-4f6a-4436-8143-90d220720df5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./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*) @ 0x000000002b0a61c0 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f608 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ab8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 23. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2cc3e5 24. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:308: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000030f336af 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000030f451f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f74818 27. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 28. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 31. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:43:35.618344 [ 8431 ] {02544da7-7c4f-4556-8071-a5b565b72e8a} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Nano takes one or two arguments: In scope SELECT fromUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 591, line 592) (in query: SELECT fromUnixTimestamp64Nano();) 2025.06.13 15:43:35.726118 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Nano takes one or two arguments: In scope SELECT fromUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:35.733430 [ 5978 ] {b363e995-f159-4246-82a0-f23d07767f01} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 1, should be 0: In scope SELECT currentRoles(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 382, line 383) (in query: SELECT currentRoles(-1);) 2025.06.13 15:43:35.737658 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 1, should be 0: In scope SELECT currentRoles(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:35.795952 [ 3511 ] {8e29be3b-4f6a-4436-8143-90d220720df5::20191002_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/8e2/8e29be3b-4f6a-4436-8143-90d220720df5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:35.807656 [ 3511 ] {8e29be3b-4f6a-4436-8143-90d220720df5::20191002_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/8e2/8e29be3b-4f6a-4436-8143-90d220720df5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./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*) @ 0x000000002b0a61c0 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f608 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ab8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 23. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2cc3e5 24. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:308: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000030f336af 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000030f451f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f74818 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000030f63ea2 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:35.810451 [ 3511 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8e29be3b-4f6a-4436-8143-90d220720df5::20191002_2_2_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/8e2/8e29be3b-4f6a-4436-8143-90d220720df5/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./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*) @ 0x000000002b0a61c0 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b09f608 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ab8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b037d3e 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b036ba3 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002d627a3e 23. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000002e2cc3e5 24. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:308: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000030f336af 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000030f451f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f74818 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000030f63ea2 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:35.822764 [ 8431 ] {856618a2-c657-4c6e-9a7d-139bc4a0400c} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Second takes one or two arguments: In scope SELECT fromUnixTimestamp64Second(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 592, line 593) (in query: SELECT fromUnixTimestamp64Second();) 2025.06.13 15:43:35.836002 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Second takes one or two arguments: In scope SELECT fromUnixTimestamp64Second(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:35.839052 [ 5978 ] {5b758f20-39d5-4b75-ad6a-307ec1afa8fc} executeQuery: Code: 43. DB::Exception: Argument for function currentSchemas must be bool: In scope SELECT currentSchemas(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 383, line 384) (in query: SELECT currentSchemas(-1);) 2025.06.13 15:43:35.865816 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function currentSchemas must be bool: In scope SELECT currentSchemas(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:35.976438 [ 8431 ] {e8800895-d84d-42a1-a8d7-caa83b511eb1} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestampInJodaSyntax doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT fromUnixTimestampInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 593, line 594) (in query: SELECT fromUnixTimestampInJodaSyntax();) 2025.06.13 15:43:35.983075 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestampInJodaSyntax doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT fromUnixTimestampInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:35.989727 [ 5978 ] {e8bd46cf-1fd2-4839-b359-f992bf957407} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 1, should be 0: In scope SELECT currentUser(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 384, line 385) (in query: SELECT currentUser(-1);) 2025.06.13 15:43:36.007270 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 1, should be 0: In scope SELECT currentUser(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:36.134195 [ 8431 ] {5d785280-7fb8-4a44-b348-5708471cf88a} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT from_utc_timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 594, line 595) (in query: SELECT from_utc_timestamp();) 2025.06.13 15:43:36.145454 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT from_utc_timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:36.223530 [ 5978 ] {27acc74d-f1fb-47da-b5db-548f2b8658f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT current_database(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 385, line 386) (in query: SELECT current_database(-1);) 2025.06.13 15:43:36.246705 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 1, should be 0: In scope SELECT current_database(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:36.444005 [ 5978 ] {3e13657c-566b-4a60-a4fe-053cf95e6120} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 1, should be 0: In scope SELECT current_date(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 386, line 387) (in query: SELECT current_date(-1);) 2025.06.13 15:43:36.462689 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 1, should be 0: In scope SELECT current_date(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:36.622374 [ 8431 ] {a75edf46-badb-4e45-9d63-7a5b88aa5934} executeQuery: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 0, should be 2: In scope SELECT fuzzBits(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 596, line 597) (in query: SELECT fuzzBits();) 2025.06.13 15:43:36.633013 [ 5978 ] {b674fe6f-fe32-4453-b037-5eb54008ee78} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 1, should be 0: In scope SELECT current_query_id(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 387, line 388) (in query: SELECT current_query_id(-1);) 2025.06.13 15:43:36.634270 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 0, should be 2: In scope SELECT fuzzBits(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:36.646277 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 1, should be 0: In scope SELECT current_query_id(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:36.832532 [ 5978 ] {4d70e4fe-928f-42ac-bef8-ea640e8683d6} executeQuery: Code: 43. DB::Exception: Argument for function currentSchemas must be bool: In scope SELECT current_schemas(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 388, line 389) (in query: SELECT current_schemas(-1);) 2025.06.13 15:43:36.842960 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function currentSchemas must be bool: In scope SELECT current_schemas(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:37.037914 [ 5978 ] {a7995773-1f34-4368-912a-b6ae3cc98a2a} executeQuery: Code: 43. DB::Exception: Arguments of function now should be String or FixedString: In scope SELECT current_timestamp(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 389, line 390) (in query: SELECT current_timestamp(-1);) 2025.06.13 15:43:37.042218 [ 8431 ] {a629e0cf-ddb2-4004-8819-c10b19a1e641} executeQuery: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 0, should be 2: In scope SELECT gcd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 598, line 599) (in query: SELECT gcd();) 2025.06.13 15:43:37.043994 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function now should be String or FixedString: In scope SELECT current_timestamp(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:37.051454 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 0, should be 2: In scope SELECT gcd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:37.176839 [ 5978 ] {e8ce2123-56fd-410f-a5b9-3852c45de4e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 1, should be 0: In scope SELECT current_user(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 390, line 391) (in query: SELECT current_user(-1);) 2025.06.13 15:43:37.201109 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 1, should be 0: In scope SELECT current_user(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:37.312835 [ 5978 ] {bde5acdc-f5b6-425d-8693-7459125ab7f2} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutFragment: In scope SELECT cutFragment(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 391, line 392) (in query: SELECT cutFragment(-1);) 2025.06.13 15:43:37.329723 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutFragment: In scope SELECT cutFragment(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:37.379282 [ 8431 ] {78fe4b44-dd52-4703-94ea-980879289c40} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 0, should be 1: In scope SELECT generateSerialID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 600, line 601) (in query: SELECT generateSerialID();) 2025.06.13 15:43:37.384956 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 0, should be 1: In scope SELECT generateSerialID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:37.512393 [ 5978 ] {b6569801-31ef-4bce-a479-a5abef486d52} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 1, should be 3: In scope SELECT cutIPv6(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 392, line 393) (in query: SELECT cutIPv6(-1);) 2025.06.13 15:43:37.522894 [ 18511 ] {d5eb07c0-c27f-4e1b-9b6d-0c9c9e09a710} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC')). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50010) (comment: 02507_to_unix_timestamp_overflow.sql) (query 1, line 1) (in query: SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl(DB::DateTime64 const&, unsigned int, unsigned int&) @ 0x000000002c4a45ee 6. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>(T::FieldType const&, unsigned int) @ 0x000000002c4ac659 7. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUnixTimestamp, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b22bf5f 8. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b2259a6 9. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, 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::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02e6b7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b067c1e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b066a83 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:43:37.532253 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 1, should be 3: In scope SELECT cutIPv6(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:37.552207 [ 18511 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC')). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl(DB::DateTime64 const&, unsigned int, unsigned int&) @ 0x000000002c4a45ee 6. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>(T::FieldType const&, unsigned int) @ 0x000000002c4ac659 7. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUnixTimestamp, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b22bf5f 8. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b2259a6 9. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, 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::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02e6b7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b067c1e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b066a83 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:43:37.657306 [ 5978 ] {e229003c-11e8-41ef-aeca-2d300a9f11b6} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutQueryString: In scope SELECT cutQueryString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 393, line 394) (in query: SELECT cutQueryString(-1);) 2025.06.13 15:43:37.666136 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutQueryString: In scope SELECT cutQueryString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:37.815777 [ 5978 ] {58bab04e-52b9-455c-81c5-f3a335d91c77} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutQueryStringAndFragment: In scope SELECT cutQueryStringAndFragment(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 394, line 395) (in query: SELECT cutQueryStringAndFragment(-1);) 2025.06.13 15:43:37.836000 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutQueryStringAndFragment: In scope SELECT cutQueryStringAndFragment(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:38.044294 [ 5978 ] {a2600502-b3c7-4a7c-81e2-84cb48022bca} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutToFirstSignificantSubdomain: In scope SELECT cutToFirstSignificantSubdomain(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 395, line 396) (in query: SELECT cutToFirstSignificantSubdomain(-1);) 2025.06.13 15:43:38.054110 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutToFirstSignificantSubdomain: In scope SELECT cutToFirstSignificantSubdomain(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:38.247911 [ 5978 ] {67eb5799-2e67-4341-a500-8c21581d2dfb} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 396, line 397) (in query: SELECT cutToFirstSignificantSubdomainCustom(-1);) 2025.06.13 15:43:38.309222 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:38.383893 [ 8430 ] {0cefe8ec-2207-4fa3-a960-27e4f6399cc6} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50026) (comment: 02193_async_insert_tcp_client_2.sh) (query 1, line 1) (in query: CREATE TABLE t_async_insert_02193_2 (id UInt32, s String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:38.398340 [ 8430 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:38.425954 [ 5978 ] {78da6438-ea88-4865-90ad-b878154e828a} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 397, line 398) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC(-1);) 2025.06.13 15:43:38.446915 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:38.526251 [ 8431 ] {e74b5da9-82ac-415b-87b5-19d66cdc30a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 0, should be 4: In scope SELECT geoDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 605, line 606) (in query: SELECT geoDistance();) 2025.06.13 15:43:38.547459 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 0, should be 4: In scope SELECT geoDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:38.547575 [ 5978 ] {ef1a6195-8929-480d-88fb-74d62b5971b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 398, line 399) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW(-1);) 2025.06.13 15:43:38.569919 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:38.704411 [ 8431 ] {d6e042d4-5c48-4f7e-83c0-b2e56b9639c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 0, should be 3: In scope SELECT geoToH3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 606, line 607) (in query: SELECT geoToH3();) 2025.06.13 15:43:38.708888 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 0, should be 3: In scope SELECT geoToH3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:38.721775 [ 5978 ] {c52cd539-b151-4611-9a9b-4be0db1f3351} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 399, line 400) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(-1);) 2025.06.13 15:43:38.727283 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 1, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:38.810645 [ 8431 ] {272ba166-fe73-4558-9bee-d0ea586160af} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 0, should be 2: In scope SELECT geoToS2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 607, line 608) (in query: SELECT geoToS2();) 2025.06.13 15:43:38.815542 [ 5978 ] {f24be5e4-c514-43e0-9729-762a0faf9dd9} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutToFirstSignificantSubdomainRFC: In scope SELECT cutToFirstSignificantSubdomainRFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 400, line 401) (in query: SELECT cutToFirstSignificantSubdomainRFC(-1);) 2025.06.13 15:43:38.818510 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 0, should be 2: In scope SELECT geoToS2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:38.822054 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutToFirstSignificantSubdomainRFC: In scope SELECT cutToFirstSignificantSubdomainRFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:38.898336 [ 8431 ] {5cd72e74-d6c4-4738-ab4d-468e67d015c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 0, should be 1: In scope SELECT geohashDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 608, line 609) (in query: SELECT geohashDecode();) 2025.06.13 15:43:38.901000 [ 3895 ] {8d8b7493-f631-4846-8b97-ff41e9ff4ab2} executeQuery: Code: 60. DB::Exception: Table test_11.t_async_insert_02193_2 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50032) (comment: 02193_async_insert_tcp_client_2.sh) (query 1, line 1) (in query: INSERT INTO t_async_insert_02193_2 SETTINGS async_insert = 1 FORMAT CSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f4cd9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:43:38.910085 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 0, should be 1: In scope SELECT geohashDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:38.929892 [ 3895 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.t_async_insert_02193_2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f4cd9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:43:38.956644 [ 5978 ] {8048d73f-158d-4605-9018-2d94be62094e} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutToFirstSignificantSubdomainWithWWW: In scope SELECT cutToFirstSignificantSubdomainWithWWW(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 401, line 402) (in query: SELECT cutToFirstSignificantSubdomainWithWWW(-1);) 2025.06.13 15:43:38.975633 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutToFirstSignificantSubdomainWithWWW: In scope SELECT cutToFirstSignificantSubdomainWithWWW(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:39.021867 [ 8431 ] {0ae865fa-5f73-4716-aaed-a1dfe1db1126} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'geohashEncode'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT geohashEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 609, line 610) (in query: SELECT geohashEncode();) 2025.06.13 15:43:39.034761 [ 8442 ] {9565570a-dc77-4366-bd02-fd81d6175742} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1295, line 1297) (in query: SELECT synonyms(NULL, NULL);) 2025.06.13 15:43:39.109947 [ 8442 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:43:39.126199 [ 5978 ] {efb484f3-d515-432e-b24d-a62a7f5f3485} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutToFirstSignificantSubdomainWithWWWRFC: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 402, line 403) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC(-1);) 2025.06.13 15:43:39.152091 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutToFirstSignificantSubdomainWithWWWRFC: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:39.188793 [ 8442 ] {b4353465-4e59-4f1e-8c84-1e41604cb521} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 2, should be 1: In scope SELECT tan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1296, line 1298) (in query: SELECT tan(NULL, NULL);) 2025.06.13 15:43:39.196899 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'geohashEncode'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT geohashEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:39.205403 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 2, should be 1: In scope SELECT tan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:39.232937 [ 5978 ] {d5e03b46-4621-4730-8c54-4db03cfae3c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 1, should be 2: In scope SELECT cutURLParameter(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 403, line 404) (in query: SELECT cutURLParameter(-1);) 2025.06.13 15:43:39.253473 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 1, should be 2: In scope SELECT cutURLParameter(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:39.265082 [ 8431 ] {7ac92d1f-ead8-42f9-8008-509e44bf645e} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 0, should be 5: In scope SELECT geohashesInBox(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 610, line 611) (in query: SELECT geohashesInBox();) 2025.06.13 15:43:39.279470 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 0, should be 5: In scope SELECT geohashesInBox(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:39.390998 [ 8431 ] {6da69046-1dd0-45ba-9af0-2b274724b675} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 611, line 612) (in query: SELECT getClientHTTPHeader();) 2025.06.13 15:43:39.391288 [ 8442 ] {ee227407-9dcc-4a86-8577-ed2fbdccd260} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 2, should be 1: In scope SELECT tanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1297, line 1299) (in query: SELECT tanh(NULL, NULL);) 2025.06.13 15:43:39.392510 [ 5978 ] {14a700ad-f3e5-4a8e-897b-c8c08b5b63f1} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutWWW: In scope SELECT cutWWW(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 404, line 405) (in query: SELECT cutWWW(-1);) 2025.06.13 15:43:39.400642 [ 8431 ] {} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.06.13 15:43:39.405607 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 2, should be 1: In scope SELECT tanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:39.406447 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function cutWWW: In scope SELECT cutWWW(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:39.468946 [ 8432 ] {ca5230b6-73ad-4a87-9663-9ea78adc8732} executeQuery: Code: 60. DB::Exception: Table test_11.t_async_insert_02193_2 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50056) (comment: 02193_async_insert_tcp_client_2.sh) (query 1, line 1) (in query: INSERT INTO t_async_insert_02193_2 SETTINGS async_insert = 1 FORMAT Values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f4cd9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:43:39.492063 [ 8432 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.t_async_insert_02193_2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f4cd9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:43:39.579620 [ 8431 ] {f834095c-ec78-4319-bbf2-86e6d60d9ab3} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 0, should be 1: In scope SELECT getMacro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 612, line 613) (in query: SELECT getMacro();) 2025.06.13 15:43:39.632246 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 0, should be 1: In scope SELECT getMacro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:39.642884 [ 5978 ] {ab898c03-9039-48e2-b1c9-41e282002e7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 1, should be 2: In scope SELECT damerauLevenshteinDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 405, line 406) (in query: SELECT damerauLevenshteinDistance(-1);) 2025.06.13 15:43:39.647959 [ 8442 ] {b10f3a89-a8b6-4f91-a7b9-66b2b31fdbbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 2, should be 0: In scope SELECT tcpPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1298, line 1300) (in query: SELECT tcpPort(NULL, NULL);) 2025.06.13 15:43:39.661533 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 1, should be 2: In scope SELECT damerauLevenshteinDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:39.663620 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 2, should be 0: In scope SELECT tcpPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:39.844447 [ 8431 ] {f8b0e8de-3680-4104-ad16-bf851c0dffed} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 0, should be 1: In scope SELECT getMaxTableNameLengthForDatabase(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 613, line 614) (in query: SELECT getMaxTableNameLengthForDatabase();) 2025.06.13 15:43:39.855346 [ 8442 ] {89d351ba-1d33-41dd-b518-b33aabd11012} executeQuery: Code: 70. DB::Exception: Cannot convert NULL to a non-nullable type: In scope SELECT test_function(NULL, NULL). (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1299, line 1301) (in query: SELECT test_function(NULL, NULL);) 2025.06.13 15:43:39.856015 [ 5978 ] {7910b386-7176-45be-adc0-924bcaf7f295} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 406, line 407) (in query: SELECT dateDiff(-1);) 2025.06.13 15:43:39.856942 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 0, should be 1: In scope SELECT getMaxTableNameLengthForDatabase(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:39.862750 [ 8442 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert NULL to a non-nullable type: In scope SELECT test_function(NULL, NULL). (CANNOT_CONVERT_TYPE) 2025.06.13 15:43:39.864217 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:39.952901 [ 5978 ] {94c022aa-7cb0-48bd-9e0f-db09fd643067} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateName doesn't match: passed 1: In scope SELECT dateName(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 407, line 408) (in query: SELECT dateName(-1);) 2025.06.13 15:43:39.958301 [ 8442 ] {76cb13f1-830b-4775-aad4-d8d5ff992d66} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 2, should be 1: In scope SELECT tgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1300, line 1302) (in query: SELECT tgamma(NULL, NULL);) 2025.06.13 15:43:39.959724 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateName doesn't match: passed 1: In scope SELECT dateName(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:39.963337 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 2, should be 1: In scope SELECT tgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:40.014953 [ 5978 ] {1b739e8e-67bf-4df2-b977-7b324f563f95} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflake'. Expected: DateTime64, got: Int8: In scope SELECT dateTime64ToSnowflake(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 408, line 409) (in query: SELECT dateTime64ToSnowflake(-1);) 2025.06.13 15:43:40.020892 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflake'. Expected: DateTime64, got: Int8: In scope SELECT dateTime64ToSnowflake(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:40.057495 [ 8431 ] {d6590413-10a1-457d-b60a-d9721de3a956} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 0, should be 1: In scope SELECT getServerPort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 615, line 616) (in query: SELECT getServerPort();) 2025.06.13 15:43:40.064372 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 0, should be 1: In scope SELECT getServerPort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:40.071211 [ 8432 ] {06735b6d-c227-45c8-affd-2c1be7ed759b} executeQuery: Code: 60. DB::Exception: Table test_11.t_async_insert_02193_2 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50080) (comment: 02193_async_insert_tcp_client_2.sh) (query 1, line 1) (in query: INSERT INTO t_async_insert_02193_2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f4cd9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:43:40.101508 [ 8432 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.t_async_insert_02193_2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f4cd9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:43:40.151844 [ 5978 ] {b8aef1b3-2ade-4184-89d0-5c90189d1024} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflakeID'. Expected: DateTime64, got: Int8: In scope SELECT dateTime64ToSnowflakeID(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 409, line 410) (in query: SELECT dateTime64ToSnowflakeID(-1);) 2025.06.13 15:43:40.161668 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflakeID'. Expected: DateTime64, got: Int8: In scope SELECT dateTime64ToSnowflakeID(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:40.177630 [ 8431 ] {f0f0db19-0788-41fd-bd7c-ac76029c58da} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 0, should be 1: In scope SELECT getSetting(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 616, line 617) (in query: SELECT getSetting();) 2025.06.13 15:43:40.192905 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 0, should be 1: In scope SELECT getSetting(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:40.267438 [ 5978 ] {b0662768-5c97-45f7-b90d-66f573d5e0d3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflake'. Expected: DateTime, got: Int8: In scope SELECT dateTimeToSnowflake(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 410, line 411) (in query: SELECT dateTimeToSnowflake(-1);) 2025.06.13 15:43:40.289126 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflake'. Expected: DateTime, got: Int8: In scope SELECT dateTimeToSnowflake(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:40.320090 [ 8431 ] {c5102879-c5e0-44d2-94fe-731ee7adf814} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 0, should be 2: In scope SELECT getSettingOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 617, line 618) (in query: SELECT getSettingOrDefault();) 2025.06.13 15:43:40.349166 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 0, should be 2: In scope SELECT getSettingOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:40.394000 [ 8442 ] {57dd2879-f837-42a9-899f-f9df7345f67f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 2, should be 0: In scope SELECT tid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1303, line 1305) (in query: SELECT tid(NULL, NULL);) 2025.06.13 15:43:40.405655 [ 5978 ] {bbc21ed1-3ece-4ae0-8b39-a4cd7f9c229b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflakeID'. Expected: DateTime, got: Int8: In scope SELECT dateTimeToSnowflakeID(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 411, line 412) (in query: SELECT dateTimeToSnowflakeID(-1);) 2025.06.13 15:43:40.407202 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 2, should be 0: In scope SELECT tid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:40.426809 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflakeID'. Expected: DateTime, got: Int8: In scope SELECT dateTimeToSnowflakeID(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:40.446143 [ 8431 ] {86d0b6c8-b207-4ce8-8560-65ef1ddb5137} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 0, should be 1: In scope SELECT getSizeOfEnumType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 618, line 619) (in query: SELECT getSizeOfEnumType();) 2025.06.13 15:43:40.470767 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 0, should be 1: In scope SELECT getSizeOfEnumType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:40.722045 [ 5978 ] {9b7cd334-b94b-4bbf-a10b-282f7552a3d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 1, should be 2 or 3: In scope SELECT dateTrunc(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 412, line 413) (in query: SELECT dateTrunc(-1);) 2025.06.13 15:43:40.722685 [ 8432 ] {989bb34b-2ea4-419a-86c4-5cdd6a2b38da} executeQuery: Code: 60. DB::Exception: Table test_11.t_async_insert_02193_2 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50096) (comment: 02193_async_insert_tcp_client_2.sh) (query 1, line 1) (in query: INSERT INTO t_async_insert_02193_2 FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f4cd9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:43:40.730543 [ 8431 ] {3fdd9edc-db26-4afd-8835-40bdcb9cc813} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 0, should be 2: In scope SELECT getSubcolumn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 619, line 620) (in query: SELECT getSubcolumn();) 2025.06.13 15:43:40.753724 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 1, should be 2 or 3: In scope SELECT dateTrunc(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:40.758105 [ 8432 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.t_async_insert_02193_2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d3f4cd9 10. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f59a5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:43:40.774613 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 0, should be 2: In scope SELECT getSubcolumn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:40.862906 [ 5978 ] {0f41bfed-5850-4b4b-9b59-57024503fc4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 1, must be 2, 3 or 4: In scope SELECT date_bin(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 413, line 414) (in query: SELECT date_bin(-1);) 2025.06.13 15:43:40.883956 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 1, must be 2, 3 or 4: In scope SELECT date_bin(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:41.032569 [ 8431 ] {b8e2eee1-0487-483d-89aa-cffd3a69c92f} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 0, should be 1: In scope SELECT getTypeSerializationStreams(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 620, line 621) (in query: SELECT getTypeSerializationStreams();) 2025.06.13 15:43:41.043040 [ 5978 ] {29c648c3-1cd0-4389-8386-13cb5feffc60} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 414, line 415) (in query: SELECT date_diff(-1);) 2025.06.13 15:43:41.054354 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 0, should be 1: In scope SELECT getTypeSerializationStreams(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:41.058953 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:41.123165 [ 8431 ] {46940344-cfc4-4f84-86ba-7b1e6e326a2b} executeQuery: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 621, line 622) (in query: SELECT globalIn();) 2025.06.13 15:43:41.130711 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:41.189690 [ 8442 ] {4a606f48-16d4-40e5-9429-830e2d54d4b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1307, line 1309) (in query: SELECT timeZone(NULL, NULL);) 2025.06.13 15:43:41.211084 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:41.235282 [ 5978 ] {08ab25f8-e212-45ef-92ab-8bd56c840781} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function decodeHTMLComponent: In scope SELECT decodeHTMLComponent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 415, line 416) (in query: SELECT decodeHTMLComponent(-1);) 2025.06.13 15:43:41.270353 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function decodeHTMLComponent: In scope SELECT decodeHTMLComponent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:41.336161 [ 8431 ] {7a68ae47-cceb-4bbd-9eb6-f3858662c5b4} executeQuery: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 622, line 623) (in query: SELECT globalInIgnoreSet();) 2025.06.13 15:43:41.345179 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:41.392175 [ 8442 ] {88f7bcf0-c7d8-4571-bf43-b0e7a8b80e74} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timeZoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1308, line 1310) (in query: SELECT timeZoneOf(NULL, NULL);) 2025.06.13 15:43:41.398410 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timeZoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:41.405452 [ 5978 ] {239a96ba-7a1b-420f-8b23-cba4c4a7c439} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function decodeURLComponent: In scope SELECT decodeURLComponent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 416, line 417) (in query: SELECT decodeURLComponent(-1);) 2025.06.13 15:43:41.421738 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function decodeURLComponent: In scope SELECT decodeURLComponent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:41.447012 [ 8101 ] {01bbc715-0042-4cfb-a377-33bda16d66b4} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_async_insert_02193_2' in scope SELECT * FROM t_async_insert_02193_2 ORDER BY id ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50112) (comment: 02193_async_insert_tcp_client_2.sh) (query 1, line 1) (in query: SELECT * FROM t_async_insert_02193_2 ORDER BY id), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:43:41.477242 [ 8101 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_async_insert_02193_2' in scope SELECT * FROM t_async_insert_02193_2 ORDER BY id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:43:41.579623 [ 5978 ] {6f21449d-c1a2-43a8-8c8f-a2a074e810ab} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function decodeURLFormComponent: In scope SELECT decodeURLFormComponent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 417, line 418) (in query: SELECT decodeURLFormComponent(-1);) 2025.06.13 15:43:41.606797 [ 8431 ] {05d77dcb-16f3-4c8e-812d-4ad4fd4eb39b} executeQuery: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 623, line 624) (in query: SELECT globalNotIn();) 2025.06.13 15:43:41.635185 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function decodeURLFormComponent: In scope SELECT decodeURLFormComponent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:41.641974 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:41.692086 [ 5978 ] {2ceb54c0-be32-4e64-b34c-39375f59a014} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function decodeXMLComponent: In scope SELECT decodeXMLComponent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 418, line 419) (in query: SELECT decodeXMLComponent(-1);) 2025.06.13 15:43:41.697119 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function decodeXMLComponent: In scope SELECT decodeXMLComponent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:41.712451 [ 8431 ] {82669b9d-7bec-4ee1-9a3b-51b7b73e4d0e} executeQuery: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 624, line 625) (in query: SELECT globalNotInIgnoreSet();) 2025.06.13 15:43:41.744192 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:41.772113 [ 5978 ] {601abcc9-4cf5-4512-9a51-c940bc1594ab} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT decrypt(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 419, line 420) (in query: SELECT decrypt(-1);) 2025.06.13 15:43:41.778769 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT decrypt(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:41.832125 [ 8431 ] {b286184d-330a-4339-9ef2-e472bdf1fa55} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 625, line 626) (in query: SELECT globalNotNullIn();) 2025.06.13 15:43:41.839011 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:41.853795 [ 5978 ] {3b4cb07c-c78c-44fc-a8e8-68356500bef7} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 1, should be 0: In scope SELECT defaultProfiles(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 420, line 421) (in query: SELECT defaultProfiles(-1);) 2025.06.13 15:43:41.869067 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 1, should be 0: In scope SELECT defaultProfiles(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:41.964230 [ 8431 ] {14378eda-04e7-421b-becf-525e2a8542a3} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 626, line 627) (in query: SELECT globalNotNullInIgnoreSet();) 2025.06.13 15:43:41.975826 [ 5978 ] {5b34c6f8-9ada-4399-b30a-adcd096e227d} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 1, should be 0: In scope SELECT defaultRoles(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 421, line 422) (in query: SELECT defaultRoles(-1);) 2025.06.13 15:43:41.978741 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:41.999351 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 1, should be 0: In scope SELECT defaultRoles(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:42.017701 [ 8099 ] {c1f53ada-ea3e-4b6b-b58a-42edb96e2785} executeQuery: Code: 60. DB::Exception: Table test_11.t_async_insert_02193_2 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50114) (comment: 02193_async_insert_tcp_client_2.sh) (query 1, line 1) (in query: TRUNCATE TABLE t_async_insert_02193_2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:43:42.041072 [ 8099 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.t_async_insert_02193_2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:43:42.116538 [ 8431 ] {287de438-162b-4fa1-aca3-5393fd0d577b} executeQuery: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 627, line 628) (in query: SELECT globalNullIn();) 2025.06.13 15:43:42.230895 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:42.305625 [ 8431 ] {3a7b6996-1e34-40ef-9d97-a4a87f7245f6} executeQuery: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 628, line 629) (in query: SELECT globalNullInIgnoreSet();) 2025.06.13 15:43:42.309262 [ 5978 ] {868ddce4-1d47-43ba-b77b-d3753e978d26} executeQuery: Code: 44. DB::Exception: The argument of function defaultValueOfTypeName must be a constant string describing type.: In scope SELECT defaultValueOfTypeName(-1). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 423, line 424) (in query: SELECT defaultValueOfTypeName(-1);) 2025.06.13 15:43:42.314363 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:42.322217 [ 5978 ] {} TCPHandler: Code: 44. DB::Exception: The argument of function defaultValueOfTypeName must be a constant string describing type.: In scope SELECT defaultValueOfTypeName(-1). (ILLEGAL_COLUMN) 2025.06.13 15:43:42.328108 [ 5005 ] {8e6885ca-51b3-4269-9cdd-c1ef87c7c999} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('01/12/2017,'). (CANNOT_PARSE_DATETIME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50076) (comment: 02457_parse_date_time_best_effort.sql) (query 11, line 11) (in query: select parseDateTimeBestEffort('01/12/2017,');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000023b79901 6. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b365d56 7. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b3571ef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:43:42.357000 [ 5005 ] {} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('01/12/2017,'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000023b79901 6. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b365d56 7. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b3571ef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:43:42.449323 [ 8431 ] {b53a6c11-420e-46a3-9ea6-7ffadb851708} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 0, should be 1: In scope SELECT globalVariable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 629, line 630) (in query: SELECT globalVariable();) 2025.06.13 15:43:42.468966 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 0, should be 1: In scope SELECT globalVariable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:42.595942 [ 8442 ] {5c7ed7b9-8ffe-495e-9b47-56fe5af90df9} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1314, line 1316) (in query: SELECT timezone(NULL, NULL);) 2025.06.13 15:43:42.618712 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:42.628797 [ 8431 ] {56d73684-6c60-476d-942d-b88c234f6a43} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 0, should be 4: In scope SELECT greatCircleAngle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 630, line 631) (in query: SELECT greatCircleAngle();) 2025.06.13 15:43:42.641991 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 0, should be 4: In scope SELECT greatCircleAngle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:42.726274 [ 8442 ] {46f0efe6-d04e-4100-b1e0-84a4553b12c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timezoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1315, line 1317) (in query: SELECT timezoneOf(NULL, NULL);) 2025.06.13 15:43:42.744081 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timezoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:42.752141 [ 5005 ] {f03f8cff-949a-45b8-b6d4-c42741a99632} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffortUS('18:31:44,,,, 31/12/2015'). (CANNOT_PARSE_DATETIME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50076) (comment: 02457_parse_date_time_best_effort.sql) (query 12, line 12) (in query: select parseDateTimeBestEffortUS('18:31:44,,,, 31/12/2015');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffortUS(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000023b7baeb 6. ./src/Functions/FunctionsConversion.h:1000: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b370c56 7. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b35b3c5 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:43:42.758735 [ 5005 ] {} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffortUS('18:31:44,,,, 31/12/2015'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffortUS(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000023b7baeb 6. ./src/Functions/FunctionsConversion.h:1000: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b370c56 7. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b35b3c5 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:43:42.770057 [ 8431 ] {eeceecbf-82fa-4245-b727-230d919aeab2} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 0, should be 4: In scope SELECT greatCircleDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 631, line 632) (in query: SELECT greatCircleDistance();) 2025.06.13 15:43:42.783513 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 0, should be 4: In scope SELECT greatCircleDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:42.891698 [ 5978 ] {c9fcc64b-3e72-46ae-a2a8-ad33aa2b0578} executeQuery: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 426, line 427) (in query: SELECT deltaSumTimestamp(-1);) 2025.06.13 15:43:42.897981 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:42.901498 [ 8431 ] {96590e5c-0b7d-4c61-8278-9d10d2944ebe} executeQuery: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 0, should be 2: In scope SELECT greater(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 632, line 633) (in query: SELECT greater();) 2025.06.13 15:43:43.005147 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 0, should be 2: In scope SELECT greater(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:43.016247 [ 5978 ] {ddf298ec-4eae-4ea8-b771-8e5aafce4c6a} executeQuery: Code: 43. DB::Exception: The only argument for function demangle must be String. Found Int8 instead.: In scope SELECT demangle(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 427, line 428) (in query: SELECT demangle(-1);) 2025.06.13 15:43:43.028679 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The only argument for function demangle must be String. Found Int8 instead.: In scope SELECT demangle(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:43.087299 [ 5005 ] {93552972-07f3-4abc-923e-f8804659b635} executeQuery: Code: 6. DB::Exception: Cannot parse string '18:31:44, 31/12/2015,' as DateTime: syntax error at position 20 (parsed just '18:31:44, 31/12/2015'): In scope SELECT parseDateTimeBestEffortUS('18:31:44, 31/12/2015,'). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50076) (comment: 02457_parse_date_time_best_effort.sql) (query 13, line 13) (in query: select parseDateTimeBestEffortUS('18:31:44, 31/12/2015,');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b370df6 6. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b35b3c5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:43:43.097434 [ 5005 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '18:31:44, 31/12/2015,' as DateTime: syntax error at position 20 (parsed just '18:31:44, 31/12/2015'): In scope SELECT parseDateTimeBestEffortUS('18:31:44, 31/12/2015,'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b370df6 6. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b35b3c5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:43:43.127168 [ 8431 ] {68a536c6-7a8d-4bef-90ac-6ad6354d9fbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 0, should be 2: In scope SELECT greaterOrEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 633, line 634) (in query: SELECT greaterOrEquals();) 2025.06.13 15:43:43.130683 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 0, should be 2: In scope SELECT greaterOrEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:43.438317 [ 5978 ] {0d33d019-6b98-45fd-a0de-ec4d56dfa93a} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 428, line 429) (in query: SELECT denseRank(-1);) 2025.06.13 15:43:43.443651 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:43:43.577355 [ 8431 ] {ea6a1245-e546-42be-bc6a-ab90afb18963} executeQuery: Code: 42. DB::Exception: Function greatest cannot be called without arguments: In scope SELECT greatest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 634, line 635) (in query: SELECT greatest();) 2025.06.13 15:43:43.581836 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function greatest cannot be called without arguments: In scope SELECT greatest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:43.649872 [ 5978 ] {dc721661-0078-49f7-aae0-b6e2025b300e} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 429, line 430) (in query: SELECT dense_rank(-1);) 2025.06.13 15:43:43.655822 [ 8431 ] {cec038f5-ecc2-4ba1-a7b4-f6171c993be8} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 635, line 636) (in query: SELECT groupArray();) 2025.06.13 15:43:43.657610 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:43:43.681582 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:43.808464 [ 5005 ] {f5dab420-0aa5-4b01-8207-c3a811699cb5} executeQuery: Code: 6. DB::Exception: Cannot parse string '01/12/2017, 18:31:44,' as DateTime: syntax error at position 20 (parsed just '01/12/2017, 18:31:44'): In scope SELECT parseDateTimeBestEffort('01/12/2017, 18:31:44,'). (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50076) (comment: 02457_parse_date_time_best_effort.sql) (query 14, line 14) (in query: select parseDateTimeBestEffort('01/12/2017, 18:31:44,');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b365ef6 6. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b3571ef 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:43:43.848300 [ 5005 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '01/12/2017, 18:31:44,' as DateTime: syntax error at position 20 (parsed just '01/12/2017, 18:31:44'): In scope SELECT parseDateTimeBestEffort('01/12/2017, 18:31:44,'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b365ef6 6. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b3571ef 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:43:43.853231 [ 5978 ] {14daf89e-f4f6-49a8-95ca-0b21efe0a09e} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 430, line 431) (in query: SELECT detectCharset(-1);) 2025.06.13 15:43:43.855816 [ 8431 ] {79beedb1-c468-4870-92fd-90860d4a1518} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 636, line 637) (in query: SELECT groupArrayInsertAt();) 2025.06.13 15:43:43.857875 [ 8442 ] {259cc67d-aaeb-468c-89e9-20488f2b2b29} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 2, should be 1: In scope SELECT toBool(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1320, line 1322) (in query: SELECT toBool(NULL, NULL);) 2025.06.13 15:43:43.861640 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:43.862813 [ 5978 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:43:43.866249 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 2, should be 1: In scope SELECT toBool(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:43.930221 [ 8431 ] {b2bf9341-e169-4ce5-9f2c-6a72d24544a3} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayIntersect requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 637, line 638) (in query: SELECT groupArrayIntersect();) 2025.06.13 15:43:43.936080 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayIntersect requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:43.939346 [ 5978 ] {2f831281-9946-4d68-ab9d-5468b22339ad} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 431, line 432) (in query: SELECT detectLanguage(-1);) 2025.06.13 15:43:43.941418 [ 8442 ] {edcc6ba2-37c8-4d88-8c4b-13f1b02f1921} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 2, should be 1: In scope SELECT toColumnTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1321, line 1323) (in query: SELECT toColumnTypeName(NULL, NULL);) 2025.06.13 15:43:43.952892 [ 5978 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:43:43.956530 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 2, should be 1: In scope SELECT toColumnTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:43.971904 [ 5005 ] {16bcbd10-ac48-4221-a9e1-2739c4796ff3} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('01/12/2017, ,,,18:31:44'). (CANNOT_PARSE_DATETIME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50076) (comment: 02457_parse_date_time_best_effort.sql) (query 15, line 15) (in query: select parseDateTimeBestEffort('01/12/2017, ,,,18:31:44');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000023b79901 6. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b365d56 7. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b3571ef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:43:43.994866 [ 5005 ] {} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('01/12/2017, ,,,18:31:44'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000023b79901 6. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b365d56 7. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b3571ef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:43:44.032933 [ 8431 ] {31e5f56d-6d05-4bcd-a54d-47b6df0c908e} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 638, line 639) (in query: SELECT groupArrayLast();) 2025.06.13 15:43:44.042282 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:44.135729 [ 5978 ] {e201cb99-c9ea-45f3-822e-948bcc179940} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 432, line 433) (in query: SELECT detectLanguageMixed(-1);) 2025.06.13 15:43:44.145673 [ 5978 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:43:44.150815 [ 5005 ] {d2cebdef-e977-4fa9-bd4e-b8135dc54186} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('18:31:44 ,,,,, 31/12/2015'). (CANNOT_PARSE_DATETIME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50076) (comment: 02457_parse_date_time_best_effort.sql) (query 16, line 16) (in query: select parseDateTimeBestEffort('18:31:44 ,,,,, 31/12/2015');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000023b79901 6. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b365d56 7. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b3571ef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:43:44.156074 [ 5005 ] {} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('18:31:44 ,,,,, 31/12/2015'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x0000000023b79901 6. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002b365d56 7. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b3571ef 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:43:44.163674 [ 8431 ] {ba8d5466-d4f5-4308-b624-0a91b854379f} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayMovingAvg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 639, line 640) (in query: SELECT groupArrayMovingAvg();) 2025.06.13 15:43:44.206420 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayMovingAvg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:44.214362 [ 5978 ] {391f17ff-458d-4577-8a21-c05eeea21ca4} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 433, line 434) (in query: SELECT detectLanguageUnknown(-1);) 2025.06.13 15:43:44.225735 [ 5978 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:43:44.326520 [ 8431 ] {0b593fda-90e4-49fb-a212-35449d59f45c} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayMovingSum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 640, line 641) (in query: SELECT groupArrayMovingSum();) 2025.06.13 15:43:44.348720 [ 5978 ] {2bc662a3-62d8-421a-9c82-fe980fd452cf} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 434, line 435) (in query: SELECT detectProgrammingLanguage(-1);) 2025.06.13 15:43:44.358237 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayMovingSum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:44.371823 [ 5978 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:43:44.396335 [ 8442 ] {287392ae-6266-4376-a12f-ec1fdc300c6f} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date32. Actual Nullable(Nothing): In scope SELECT toDate32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1324, line 1326) (in query: SELECT toDate32OrDefault(NULL, NULL);) 2025.06.13 15:43:44.417241 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date32. Actual Nullable(Nothing): In scope SELECT toDate32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:43:44.446242 [ 8431 ] {86c160b5-63c5-456e-b9ee-2a20ca57d09e} executeQuery: Code: 42. DB::Exception: Aggregate function groupArraySample requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 641, line 642) (in query: SELECT groupArraySample();) 2025.06.13 15:43:44.453582 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArraySample requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:44.475502 [ 5978 ] {a1395247-3341-4d84-90bd-e9961f325210} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 435, line 436) (in query: SELECT detectTonality(-1);) 2025.06.13 15:43:44.494949 [ 5978 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:43:44.570246 [ 8431 ] {68ac94f4-ca2c-4fc8-9e29-85e2ad6d1d03} executeQuery: Code: 42. DB::Exception: Aggregate function groupArraySorted requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 642, line 643) (in query: SELECT groupArraySorted();) 2025.06.13 15:43:44.604290 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArraySorted requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:44.672169 [ 5978 ] {1fb3a874-9d55-4ecf-8428-c1c81ceeae0c} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 436, line 437) (in query: SELECT dictGet(-1);) 2025.06.13 15:43:44.695888 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:44.737532 [ 8431 ] {eb6ec798-ac55-4a37-a31b-33154b87dec3} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 643, line 644) (in query: SELECT groupBitAnd();) 2025.06.13 15:43:44.768945 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:44.961180 [ 5978 ] {09721ed3-1c59-4aa2-b417-6a1e0cc002e0} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 437, line 438) (in query: SELECT dictGetAll(-1);) 2025.06.13 15:43:44.961647 [ 8431 ] {e6d4fa1b-5c22-4cce-87fa-ecfd9efa0c4e} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 644, line 645) (in query: SELECT groupBitOr();) 2025.06.13 15:43:44.971678 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:44.972203 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:45.103911 [ 8431 ] {a2dfbe33-9178-40b5-897a-8ccec71802d2} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 645, line 646) (in query: SELECT groupBitXor();) 2025.06.13 15:43:45.104057 [ 5978 ] {4c53d7cf-bd34-4b76-be0f-da59bc403b66} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 1, should be 2: In scope SELECT dictGetChildren(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 438, line 439) (in query: SELECT dictGetChildren(-1);) 2025.06.13 15:43:45.106724 [ 8442 ] {510c490f-5b30-4885-94a0-6168de928883} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date. Actual Nullable(Nothing): In scope SELECT toDateOrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1327, line 1329) (in query: SELECT toDateOrDefault(NULL, NULL);) 2025.06.13 15:43:45.112030 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 1, should be 2: In scope SELECT dictGetChildren(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:45.112594 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:45.115763 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date. Actual Nullable(Nothing): In scope SELECT toDateOrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:43:45.376534 [ 5978 ] {6e9da033-3a4b-40b4-b82b-3ae9bef15454} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDate doesn't match: the function requires more arguments: In scope SELECT dictGetDate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 439, line 440) (in query: SELECT dictGetDate(-1);) 2025.06.13 15:43:45.376805 [ 8431 ] {1884b90c-1ebf-4a00-a181-7ff1a5a69db7} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmap requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 646, line 647) (in query: SELECT groupBitmap();) 2025.06.13 15:43:45.384787 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmap requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:45.434886 [ 8431 ] {eeae260f-ee5f-4be1-8bd5-b6a3f3297f2a} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 647, line 648) (in query: SELECT groupBitmapAnd();) 2025.06.13 15:43:45.440828 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:45.451506 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDate doesn't match: the function requires more arguments: In scope SELECT dictGetDate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:45.588295 [ 5978 ] {994e8478-5971-42d5-9f15-0a77fbf5975d} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateOrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 440, line 441) (in query: SELECT dictGetDateOrDefault(-1);) 2025.06.13 15:43:45.593053 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateOrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:45.598602 [ 8431 ] {6add4556-96b3-48ae-9c25-9bc44351d3ef} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 648, line 649) (in query: SELECT groupBitmapOr();) 2025.06.13 15:43:45.620634 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:45.739684 [ 5978 ] {e0703d18-d3c4-4686-9bab-6802ff444701} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateTime doesn't match: the function requires more arguments: In scope SELECT dictGetDateTime(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 441, line 442) (in query: SELECT dictGetDateTime(-1);) 2025.06.13 15:43:45.741719 [ 8431 ] {88b40b3c-c60a-4fe5-a26f-6fc09471106e} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 649, line 650) (in query: SELECT groupBitmapXor();) 2025.06.13 15:43:45.747544 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateTime doesn't match: the function requires more arguments: In scope SELECT dictGetDateTime(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:45.750538 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:45.866824 [ 5978 ] {732bce09-1b5c-4419-9f96-e6ee3126a680} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateTimeOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateTimeOrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 442, line 443) (in query: SELECT dictGetDateTimeOrDefault(-1);) 2025.06.13 15:43:45.894065 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateTimeOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateTimeOrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:45.903875 [ 8431 ] {11514047-9858-414f-bb5b-270b4e8cb7ea} executeQuery: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 650, line 651) (in query: SELECT groupConcat();) 2025.06.13 15:43:45.911382 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:46.136180 [ 8431 ] {150254a8-da84-4ab9-8d4a-8a38ef7a5861} executeQuery: Code: 42. DB::Exception: Aggregate function groupUniqArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 651, line 652) (in query: SELECT groupUniqArray();) 2025.06.13 15:43:46.138392 [ 5978 ] {6bf0c34d-6099-48cc-8020-dd2b117b19d5} executeQuery: Code: 42. DB::Exception: Illegal arguments size of function dictGetDescendants. Expects 2 or 3 arguments size. Actual size 1: In scope SELECT dictGetDescendants(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 443, line 444) (in query: SELECT dictGetDescendants(-1);) 2025.06.13 15:43:46.172780 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Illegal arguments size of function dictGetDescendants. Expects 2 or 3 arguments size. Actual size 1: In scope SELECT dictGetDescendants(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:46.173123 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupUniqArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:46.237761 [ 5978 ] {bedab4a7-75f7-42f6-8d88-53c36683f718} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 444, line 445) (in query: SELECT dictGetFloat32(-1);) 2025.06.13 15:43:46.244513 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:46.303324 [ 8442 ] {bc561525-bf70-4925-9e2e-0d1e6cf0034e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1333, line 1335) (in query: SELECT toDateTime64OrDefault(NULL, NULL);) 2025.06.13 15:43:46.308549 [ 8431 ] {5c61132d-640a-4827-876e-963f821c4d67} executeQuery: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 652, line 653) (in query: SELECT group_concat();) 2025.06.13 15:43:46.312767 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:46.324504 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:46.378227 [ 5978 ] {093a9f3a-1f61-417e-ba45-6892d83804a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 445, line 446) (in query: SELECT dictGetFloat32OrDefault(-1);) 2025.06.13 15:43:46.378595 [ 8099 ] {6204fb89-abb9-4517-a945-f1839c985c43} executeQuery: Code: 490. DB::Exception: Value cannot be represented as date because it's out of range: In scope SELECT fromModifiedJulianDay(-678942). (CANNOT_FORMAT_DATETIME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52322) (comment: 01544_fromModifiedJulianDay.sql) (query 7, line 9) (in query: SELECT fromModifiedJulianDay(-678942);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::OrdinalDate::init(long) @ 0x0000000018d45af7 6. DB::GregorianDate::GregorianDate(long) @ 0x0000000018d452a1 7. DB::ExecutableFunctionFromModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae477cc 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:43:46.394909 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:46.406725 [ 8099 ] {} TCPHandler: Code: 490. DB::Exception: Value cannot be represented as date because it's out of range: In scope SELECT fromModifiedJulianDay(-678942). (CANNOT_FORMAT_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::OrdinalDate::init(long) @ 0x0000000018d45af7 6. DB::GregorianDate::GregorianDate(long) @ 0x0000000018d452a1 7. DB::ExecutableFunctionFromModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae477cc 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:43:46.516721 [ 8431 ] {1745b03a-e296-42be-baa5-a348cc45ab73} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 0, should be 1: In scope SELECT h3CellAreaM2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 653, line 654) (in query: SELECT h3CellAreaM2();) 2025.06.13 15:43:46.579729 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 0, should be 1: In scope SELECT h3CellAreaM2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:46.677347 [ 5978 ] {91ac021a-62f9-47c1-8e3d-79b975d53985} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 446, line 447) (in query: SELECT dictGetFloat64(-1);) 2025.06.13 15:43:46.678386 [ 8431 ] {63898e29-653c-4bbe-8db3-c73c09119228} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 0, should be 1: In scope SELECT h3CellAreaRads2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 654, line 655) (in query: SELECT h3CellAreaRads2();) 2025.06.13 15:43:46.681766 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:46.686232 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 0, should be 1: In scope SELECT h3CellAreaRads2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:46.792036 [ 18602 ] {3380fcce-9892-4b87-9f8e-bfff0c44ef4b} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52352) (comment: 02377_extend_protocol_with_query_parameters.sh) (query 1, line 2) (in query: CREATE TABLE t_02377_extend_protocol_with_query_parameters_1000332089 (`id` Int64, `arr` Array(UInt8), `map` Map(String, UInt8), `mul_arr` Array(Array(UInt8)), `map_arr` Map(UInt8, Array(UInt8)), `map_map_arr` Map(String, Map(String, Array(UInt8)))) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 164, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 23, min_bytes_for_full_part_storage = 134790434, compact_parts_max_bytes_to_buffer = 293684632, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 5231487, merge_max_block_size = 11159, 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 = 7581016329, index_granularity_bytes = 11058436, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 76502, primary_key_compress_block_size = 36022, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:46.797329 [ 18602 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:46.891589 [ 5978 ] {e7558eaf-a361-43d8-a42f-3b7a181eae60} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 447, line 448) (in query: SELECT dictGetFloat64OrDefault(-1);) 2025.06.13 15:43:46.913754 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:46.924565 [ 8431 ] {6bca64c3-abbc-4155-b078-138d2c239fb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 0, should be 2: In scope SELECT h3Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 655, line 656) (in query: SELECT h3Distance();) 2025.06.13 15:43:46.931114 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 0, should be 2: In scope SELECT h3Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:46.997856 [ 8442 ] {f8395b20-cffc-47de-8f48-46efba6818c3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1336, line 1338) (in query: SELECT toDateTimeOrDefault(NULL, NULL);) 2025.06.13 15:43:47.006149 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:47.029359 [ 8431 ] {da5520ab-4141-4664-80f9-501299ac84fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 0, should be 1: In scope SELECT h3EdgeAngle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 656, line 657) (in query: SELECT h3EdgeAngle();) 2025.06.13 15:43:47.041625 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 0, should be 1: In scope SELECT h3EdgeAngle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:47.041999 [ 5978 ] {cb772fcc-c08a-4f07-a3da-78a7f86408a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 1, should be 2: In scope SELECT dictGetHierarchy(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 448, line 449) (in query: SELECT dictGetHierarchy(-1);) 2025.06.13 15:43:47.046466 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 1, should be 2: In scope SELECT dictGetHierarchy(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:47.215220 [ 8099 ] {fdbf8a78-af18-47c7-96e3-b455cc76b931} executeQuery: Code: 490. DB::Exception: Value cannot be represented as date because it's out of range: In scope SELECT fromModifiedJulianDay(2973484). (CANNOT_FORMAT_DATETIME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52322) (comment: 01544_fromModifiedJulianDay.sql) (query 10, line 12) (in query: SELECT fromModifiedJulianDay(2973484);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::OrdinalDate::init(long) @ 0x0000000018d45af7 6. DB::GregorianDate::GregorianDate(long) @ 0x0000000018d452a1 7. DB::ExecutableFunctionFromModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae39f6c 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:43:47.219506 [ 8099 ] {} TCPHandler: Code: 490. DB::Exception: Value cannot be represented as date because it's out of range: In scope SELECT fromModifiedJulianDay(2973484). (CANNOT_FORMAT_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::OrdinalDate::init(long) @ 0x0000000018d45af7 6. DB::GregorianDate::GregorianDate(long) @ 0x0000000018d452a1 7. DB::ExecutableFunctionFromModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae39f6c 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:43:47.292230 [ 8431 ] {11978402-c24e-4eb4-81c9-90c1024c158a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 0, should be 1: In scope SELECT h3EdgeLengthKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 657, line 658) (in query: SELECT h3EdgeLengthKm();) 2025.06.13 15:43:47.293077 [ 5978 ] {c4c0ec43-ed04-4c5c-ad4f-3a301900d5dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 449, line 450) (in query: SELECT dictGetIPv4(-1);) 2025.06.13 15:43:47.296621 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 0, should be 1: In scope SELECT h3EdgeLengthKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:47.298859 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:47.375925 [ 8431 ] {4b34dfd1-33cd-4376-806f-bce430a8b1bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 0, should be 1: In scope SELECT h3EdgeLengthM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 658, line 659) (in query: SELECT h3EdgeLengthM();) 2025.06.13 15:43:47.382719 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 0, should be 1: In scope SELECT h3EdgeLengthM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:47.402434 [ 5978 ] {9be772dd-3063-4ddf-9d07-d50e8d943b0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 450, line 451) (in query: SELECT dictGetIPv4OrDefault(-1);) 2025.06.13 15:43:47.408590 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:47.434356 [ 8101 ] {19b5eb7d-7b2e-4477-a758-c882746fea87} executeQuery: Code: 60. DB::Exception: Table test_11.t_02377_extend_protocol_with_query_parameters_1000332089 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52362) (comment: 02377_extend_protocol_with_query_parameters.sh) (query 1, line 1) (in query: insert into t_02377_extend_protocol_with_query_parameters_1000332089 values), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:47.453543 [ 8101 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.t_02377_extend_protocol_with_query_parameters_1000332089 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:47.511147 [ 8431 ] {80659e32-4481-4cdb-9dbb-0120b79a9826} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 659, line 660) (in query: SELECT h3ExactEdgeLengthKm();) 2025.06.13 15:43:47.520027 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:47.547497 [ 5978 ] {5d7f83bb-b84d-4727-ac39-6b6bac90cb5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 451, line 452) (in query: SELECT dictGetIPv6(-1);) 2025.06.13 15:43:47.561022 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:47.626424 [ 8431 ] {6245bbed-1da3-4de2-ac3d-92d6b396a4fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 660, line 661) (in query: SELECT h3ExactEdgeLengthM();) 2025.06.13 15:43:47.642457 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:47.657343 [ 5978 ] {a4b7cc94-43f0-41c8-b39e-643f74849a1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 452, line 453) (in query: SELECT dictGetIPv6OrDefault(-1);) 2025.06.13 15:43:47.667335 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:47.715939 [ 8431 ] {cfcf79d3-248f-476c-917d-6bf14f0a160c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthRads(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 661, line 662) (in query: SELECT h3ExactEdgeLengthRads();) 2025.06.13 15:43:47.759667 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthRads(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:47.802109 [ 5978 ] {dbeffdc0-a55e-4f0e-96a4-748551c85da7} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetInt16(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 453, line 454) (in query: SELECT dictGetInt16(-1);) 2025.06.13 15:43:47.822751 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetInt16(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:47.832660 [ 8431 ] {34cfdb03-5324-4723-94fc-6d776ac49e91} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 0, should be 1: In scope SELECT h3GetBaseCell(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 662, line 663) (in query: SELECT h3GetBaseCell();) 2025.06.13 15:43:47.838026 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 0, should be 1: In scope SELECT h3GetBaseCell(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:47.892427 [ 3526 ] {} test_13.rmt2 (6bcc1d80-e1cb-4aac-a820-17ba5a1fc6b0): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://6c2391fa62b7:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_13%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6c93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6cb2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6c821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 13. DB::ReadBuffer::next() @ 0x0000000017e74832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ad9e05 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003072cbde 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000305fe99c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305ea708 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305d537f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030728ae5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031122394 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030635cff 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003072a488 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b3595c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c632bd 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c63eff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:47.964705 [ 5978 ] {4d99790d-6d1f-43ca-a47d-14b7bd61c863} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt16OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 454, line 455) (in query: SELECT dictGetInt16OrDefault(-1);) 2025.06.13 15:43:47.972630 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt16OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:48.027100 [ 8431 ] {1cd4ae36-98d2-44d9-8711-d96455ced5a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 663, line 664) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge();) 2025.06.13 15:43:48.028681 [ 2860 ] {609447ec-5f07-49f8-84d9-2b5ddd3fc026} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_02377_extend_protocol_with_query_parameters_1000332089' in scope SELECT * FROM t_02377_extend_protocol_with_query_parameters_1000332089. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52374) (comment: 02377_extend_protocol_with_query_parameters.sh) (query 1, line 1) (in query: select * from t_02377_extend_protocol_with_query_parameters_1000332089), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:43:48.034699 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:48.054580 [ 2860 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_02377_extend_protocol_with_query_parameters_1000332089' in scope SELECT * FROM t_02377_extend_protocol_with_query_parameters_1000332089. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:43:48.094469 [ 5978 ] {620ff03d-56b1-4e4d-b197-e84e1c381b02} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetInt32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 455, line 456) (in query: SELECT dictGetInt32(-1);) 2025.06.13 15:43:48.102057 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetInt32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:48.140224 [ 8431 ] {67341c0a-13c2-4e5a-bd8b-bf9127adff1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 0, should be 1: In scope SELECT h3GetFaces(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 664, line 665) (in query: SELECT h3GetFaces();) 2025.06.13 15:43:48.151497 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 0, should be 1: In scope SELECT h3GetFaces(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:48.215607 [ 3522 ] {} test_13.rmt2 (6bcc1d80-e1cb-4aac-a820-17ba5a1fc6b0): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://6c2391fa62b7:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_13%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6c93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6cb2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6c821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 13. DB::ReadBuffer::next() @ 0x0000000017e74832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ad9e05 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003072cbde 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000305fe99c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305ea708 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305d537f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030728ae5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031122394 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030635cff 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003072a488 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b3595c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c632bd 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c63eff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:48.224671 [ 3521 ] {} test_13.rmt2 (6bcc1d80-e1cb-4aac-a820-17ba5a1fc6b0): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://6c2391fa62b7:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_13%2F02438%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6c93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6cb2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6c821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 13. DB::ReadBuffer::next() @ 0x0000000017e74832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ad9e05 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003072cbde 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000305fe99c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305ea708 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305d537f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030728ae5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031122394 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030635cff 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003072a488 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b3595c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c632bd 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c63eff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:48.338654 [ 5978 ] {5177eb7e-42bc-48aa-859c-cf214f81aaab} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt32OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 456, line 457) (in query: SELECT dictGetInt32OrDefault(-1);) 2025.06.13 15:43:48.345934 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt32OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:48.358514 [ 8431 ] {a6778caa-a5b9-412f-ac8e-531c03ea32f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 665, line 666) (in query: SELECT h3GetIndexesFromUnidirectionalEdge();) 2025.06.13 15:43:48.369917 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:48.417187 [ 5978 ] {1ff725cd-2fbd-40be-b658-7fe790ae31be} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetInt64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 457, line 458) (in query: SELECT dictGetInt64(-1);) 2025.06.13 15:43:48.418828 [ 8431 ] {e282057d-2381-455f-bdc6-401b13563e6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 666, line 667) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge();) 2025.06.13 15:43:48.423149 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetInt64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:48.423843 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:48.439368 [ 8442 ] {c6543774-2703-422f-b31b-944ccd1878a5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1344, line 1346) (in query: SELECT toDecimal128OrDefault(NULL, NULL);) 2025.06.13 15:43:48.452724 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:48.490416 [ 8431 ] {57b40469-1ade-48c0-b451-4c80b6a529d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 0, should be 1: In scope SELECT h3GetPentagonIndexes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 667, line 668) (in query: SELECT h3GetPentagonIndexes();) 2025.06.13 15:43:48.496065 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 0, should be 1: In scope SELECT h3GetPentagonIndexes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:48.621017 [ 5978 ] {e79b7163-1cc4-470f-abf9-d8ca87680421} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt64OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 458, line 459) (in query: SELECT dictGetInt64OrDefault(-1);) 2025.06.13 15:43:48.629247 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt64OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:48.807226 [ 8431 ] {d22f33ff-d49e-4e29-8313-865930f44b4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 0, should be 1: In scope SELECT h3GetResolution(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 669, line 670) (in query: SELECT h3GetResolution();) 2025.06.13 15:43:48.826851 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 0, should be 1: In scope SELECT h3GetResolution(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:48.857092 [ 5978 ] {5930f8cb-73a1-4747-8e46-7df78c4f1d09} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetInt8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 459, line 460) (in query: SELECT dictGetInt8(-1);) 2025.06.13 15:43:48.871235 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetInt8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:48.981352 [ 8431 ] {a3626b48-7b03-487b-8ead-34aaab0c71ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 0, should be 2: In scope SELECT h3GetUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 670, line 671) (in query: SELECT h3GetUnidirectionalEdge();) 2025.06.13 15:43:48.989914 [ 3537 ] {} test_13.rmt2 (6bcc1d80-e1cb-4aac-a820-17ba5a1fc6b0): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://6c2391fa62b7:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_13%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6c93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6cb2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6c821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 13. DB::ReadBuffer::next() @ 0x0000000017e74832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ad9e05 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003072cbde 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000305fe99c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305ea708 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305d537f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030728ae5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031122394 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030635cff 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003072a488 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b3595c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c632bd 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c63eff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:48.990038 [ 3535 ] {} test_13.rmt2 (6bcc1d80-e1cb-4aac-a820-17ba5a1fc6b0): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://6c2391fa62b7:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_13%2F02438%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6c93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6cb2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6c821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 13. DB::ReadBuffer::next() @ 0x0000000017e74832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ad9e05 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003072cbde 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000305fe99c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305ea708 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305d537f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030728ae5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031122394 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030635cff 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003072a488 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b3595c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c632bd 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c63eff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:48.990488 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 0, should be 2: In scope SELECT h3GetUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:48.993239 [ 5978 ] {2bcb6ac1-e7fd-48bd-8a57-f4b6e47dd0e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt8OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 460, line 461) (in query: SELECT dictGetInt8OrDefault(-1);) 2025.06.13 15:43:49.018065 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt8OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:49.126609 [ 5978 ] {5a225d12-3e11-492d-8642-9459170456f5} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 461, line 462) (in query: SELECT dictGetOrDefault(-1);) 2025.06.13 15:43:49.127689 [ 8431 ] {230cf012-e711-42bf-b013-4188da4275f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 0, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 671, line 672) (in query: SELECT h3GetUnidirectionalEdgeBoundary();) 2025.06.13 15:43:49.132620 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:49.152372 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 0, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:49.251288 [ 5978 ] {18ec6feb-2568-41bd-b09b-d0fe032e0be5} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 462, line 463) (in query: SELECT dictGetOrNull(-1);) 2025.06.13 15:43:49.253101 [ 8431 ] {e32b9081-20ee-480c-aa83-95baf80f58fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 0, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 672, line 673) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon();) 2025.06.13 15:43:49.258603 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 0, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:49.259637 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:49.273671 [ 8442 ] {2870bc04-ac65-4e60-8da2-4678ed53433a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1348, line 1350) (in query: SELECT toDecimal256OrDefault(NULL, NULL);) 2025.06.13 15:43:49.305554 [ 3531 ] {} test_13.rmt2 (6bcc1d80-e1cb-4aac-a820-17ba5a1fc6b0): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://6c2391fa62b7:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_13%2F02438%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6c93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6cb2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6c821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 13. DB::ReadBuffer::next() @ 0x0000000017e74832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ad9e05 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003072cbde 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000305fe99c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305ea708 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305d537f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030728ae5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031122394 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030635cff 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003072a488 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b3595c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c632bd 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c63eff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:49.311119 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:49.323263 [ 3530 ] {} test_13.rmt2 (6bcc1d80-e1cb-4aac-a820-17ba5a1fc6b0): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://6c2391fa62b7:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_13%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6c93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6cb2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6c821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 13. DB::ReadBuffer::next() @ 0x0000000017e74832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ad9e05 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003072cbde 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000305fe99c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305ea708 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305d537f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030728ae5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031122394 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030635cff 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003072a488 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b3595c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c632bd 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c63eff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:49.352869 [ 8431 ] {666ab3a8-43f5-4696-9681-a4b624cd1387} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 0, should be 1: In scope SELECT h3HexAreaKm2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 673, line 674) (in query: SELECT h3HexAreaKm2();) 2025.06.13 15:43:49.365460 [ 5978 ] {dc0b8a09-3c13-4310-b1c3-9fb69f710f94} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetString doesn't match: the function requires more arguments: In scope SELECT dictGetString(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 463, line 464) (in query: SELECT dictGetString(-1);) 2025.06.13 15:43:49.367296 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 0, should be 1: In scope SELECT h3HexAreaKm2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:49.371652 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetString doesn't match: the function requires more arguments: In scope SELECT dictGetString(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:49.475633 [ 8431 ] {508c1a62-d42e-4c12-be96-ba35ac719df7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 0, should be 1: In scope SELECT h3HexAreaM2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 674, line 675) (in query: SELECT h3HexAreaM2();) 2025.06.13 15:43:49.482412 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 0, should be 1: In scope SELECT h3HexAreaM2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:49.484354 [ 3526 ] {} test_13.rmt2 (6bcc1d80-e1cb-4aac-a820-17ba5a1fc6b0): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://6c2391fa62b7:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_13%2F02438%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6c93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6cb2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6c821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 13. DB::ReadBuffer::next() @ 0x0000000017e74832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ad9e05 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003072cbde 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000305fe99c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305ea708 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305d537f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030728ae5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031122394 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030635cff 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003072a488 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b3595c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c632bd 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c63eff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:49.486160 [ 3524 ] {} test_13.rmt2 (6bcc1d80-e1cb-4aac-a820-17ba5a1fc6b0): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://6c2391fa62b7:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_13%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6c93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6cb2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6c821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 13. DB::ReadBuffer::next() @ 0x0000000017e74832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ad9e05 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003072cbde 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000305fe99c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305ea708 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305d537f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030728ae5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031122394 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030635cff 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003072a488 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b3595c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c632bd 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c63eff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:49.523958 [ 5978 ] {5b58c6b9-f55e-4995-b20d-46478608627d} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetStringOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetStringOrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 464, line 465) (in query: SELECT dictGetStringOrDefault(-1);) 2025.06.13 15:43:49.536143 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetStringOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetStringOrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:49.753698 [ 8431 ] {ef7913bc-95ef-40ac-b64a-1d6557519801} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 0, should be 2: In scope SELECT h3HexRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 675, line 676) (in query: SELECT h3HexRing();) 2025.06.13 15:43:49.769984 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 0, should be 2: In scope SELECT h3HexRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:49.775575 [ 5978 ] {b0f42b49-d26d-4677-81dc-85bbe88cabc1} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 465, line 466) (in query: SELECT dictGetUInt16(-1);) 2025.06.13 15:43:49.782516 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:49.894705 [ 8431 ] {66ba7594-9e6b-42c9-8c58-403649458764} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 0, should be 2: In scope SELECT h3IndexesAreNeighbors(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 676, line 677) (in query: SELECT h3IndexesAreNeighbors();) 2025.06.13 15:43:49.903614 [ 5978 ] {60fd9e42-34c3-4d7e-9bca-6a25365c8184} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 466, line 467) (in query: SELECT dictGetUInt16OrDefault(-1);) 2025.06.13 15:43:49.904083 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 0, should be 2: In scope SELECT h3IndexesAreNeighbors(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:49.975354 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:49.998847 [ 3536 ] {} test_13.rmt2 (6bcc1d80-e1cb-4aac-a820-17ba5a1fc6b0): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://6c2391fa62b7:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_13%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6c93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6cb2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6c821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 13. DB::ReadBuffer::next() @ 0x0000000017e74832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ad9e05 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003072cbde 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000305fe99c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305ea708 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305d537f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030728ae5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031122394 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030635cff 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003072a488 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b3595c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c632bd 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c63eff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:50.001745 [ 3522 ] {} test_13.rmt2 (6bcc1d80-e1cb-4aac-a820-17ba5a1fc6b0): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://6c2391fa62b7:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_13%2F02438%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6c93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6cb2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6c821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 13. DB::ReadBuffer::next() @ 0x0000000017e74832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ad9e05 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003072cbde 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000305fe99c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305ea708 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305d537f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030728ae5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031122394 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030635cff 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003072a488 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b3595c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c632bd 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c63eff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:50.048182 [ 8431 ] {8cbc0040-8316-4bc9-bd8e-22c6d55fb43a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 0, should be 1: In scope SELECT h3IsPentagon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 677, line 678) (in query: SELECT h3IsPentagon();) 2025.06.13 15:43:50.059963 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 0, should be 1: In scope SELECT h3IsPentagon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:50.060224 [ 5978 ] {28ac6b56-2858-432f-9e95-8c554438e7f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 467, line 468) (in query: SELECT dictGetUInt32(-1);) 2025.06.13 15:43:50.081309 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:50.177985 [ 8431 ] {1f0febea-6acf-49b3-b08a-4504cd98ad72} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 0, should be 1: In scope SELECT h3IsResClassIII(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 678, line 679) (in query: SELECT h3IsResClassIII();) 2025.06.13 15:43:50.204557 [ 8442 ] {6ebe2d06-bef0-40f3-9eca-2d6dfbfb078a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1352, line 1354) (in query: SELECT toDecimal32OrDefault(NULL, NULL);) 2025.06.13 15:43:50.206604 [ 18602 ] {cc5c0e83-7375-44d3-9ebf-ebb684e3d0af} executeQuery: Code: 456. DB::Exception: Substitution `n` is not set. (UNKNOWN_QUERY_PARAMETER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52426) (comment: 02377_extend_protocol_with_query_parameters.sh) (query 1, line 1) (in query: select {n: UInt8} -- { serverError 456 }), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:71: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x000000002e283c36 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:80: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x000000002e281c7d 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1042: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29e313 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:43:50.214994 [ 18602 ] {} TCPHandler: Code: 456. DB::Exception: Substitution `n` is not set. (UNKNOWN_QUERY_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:71: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x000000002e283c36 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:80: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x000000002e281c7d 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1042: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29e313 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:43:50.216528 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:50.218292 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 0, should be 1: In scope SELECT h3IsResClassIII(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:50.235114 [ 5978 ] {810fe61d-5fff-4c30-8cfa-bd11afd0cf95} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 468, line 469) (in query: SELECT dictGetUInt32OrDefault(-1);) 2025.06.13 15:43:50.255738 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:50.279843 [ 3534 ] {} test_13.rmt2 (6bcc1d80-e1cb-4aac-a820-17ba5a1fc6b0): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://6c2391fa62b7:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_13%2F02438%2Freplicas%2F1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6c93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6cb2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6c821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 13. DB::ReadBuffer::next() @ 0x0000000017e74832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ad9e05 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003072cbde 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000305fe99c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305ea708 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305d537f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030728ae5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031122394 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030635cff 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003072a488 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b3595c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c632bd 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c63eff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:50.290941 [ 3523 ] {} test_13.rmt2 (6bcc1d80-e1cb-4aac-a820-17ba5a1fc6b0): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://6c2391fa62b7:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2Ftest_13%2F02438%2Freplicas%2F1&part=all_1_1_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 136 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6c93c 5. ./src/IO/HTTPCommon.h:33: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000023f6cb2f 6. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000023f6c821 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510f0b 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 13. DB::ReadBuffer::next() @ 0x0000000017e74832 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 16. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x0000000030ad9e05 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000003072cbde 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000305fe99c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000305ea708 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x00000000305d537f 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000030728ae5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031122394 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000030635cff 24. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003072a488 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030b3595c 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c632bd 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c63eff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:50.309774 [ 8431 ] {7d9e7197-f50a-4b3f-80cb-7046151da672} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 0, should be 1: In scope SELECT h3IsValid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 679, line 680) (in query: SELECT h3IsValid();) 2025.06.13 15:43:50.328180 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 0, should be 1: In scope SELECT h3IsValid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:50.360836 [ 5978 ] {00c0f5da-eeaa-4ecf-9164-6a5421742965} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 469, line 470) (in query: SELECT dictGetUInt64(-1);) 2025.06.13 15:43:50.465296 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:50.536727 [ 5978 ] {10852304-7c43-4950-aebd-8b8eeba89e15} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 470, line 471) (in query: SELECT dictGetUInt64OrDefault(-1);) 2025.06.13 15:43:50.536872 [ 8431 ] {c72e26bd-6da6-493f-b9b1-02999c1d1ef8} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 0, should be 2: In scope SELECT h3Line(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 680, line 681) (in query: SELECT h3Line();) 2025.06.13 15:43:50.555172 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:50.555734 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 0, should be 2: In scope SELECT h3Line(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:50.705009 [ 8431 ] {84d37a21-6c4a-4b6f-a44e-00683eb833f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 0, should be 1: In scope SELECT h3NumHexagons(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 681, line 682) (in query: SELECT h3NumHexagons();) 2025.06.13 15:43:50.727747 [ 5978 ] {16ff978e-3afc-450b-ac82-67b096b79bab} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 471, line 472) (in query: SELECT dictGetUInt8(-1);) 2025.06.13 15:43:50.732476 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 0, should be 1: In scope SELECT h3NumHexagons(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:50.736814 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:50.876634 [ 8431 ] {f4c2c217-974d-44cd-8118-830c3062caec} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 0, should be 4: In scope SELECT h3PointDistKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 682, line 683) (in query: SELECT h3PointDistKm();) 2025.06.13 15:43:50.882571 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 0, should be 4: In scope SELECT h3PointDistKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:50.885437 [ 5978 ] {60ea556a-d598-4134-a6e5-19d2880f2fd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 472, line 473) (in query: SELECT dictGetUInt8OrDefault(-1);) 2025.06.13 15:43:50.903542 [ 8442 ] {d755ad53-cd2b-4ff9-9817-c462b0584bfe} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1356, line 1358) (in query: SELECT toDecimal64OrDefault(NULL, NULL);) 2025.06.13 15:43:50.922876 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:50.932330 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:51.022231 [ 5978 ] {6db1a036-8bbf-4dd1-bf8d-580085baca36} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUUID doesn't match: the function requires more arguments: In scope SELECT dictGetUUID(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 473, line 474) (in query: SELECT dictGetUUID(-1);) 2025.06.13 15:43:51.026525 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUUID doesn't match: the function requires more arguments: In scope SELECT dictGetUUID(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:51.049199 [ 8431 ] {a69c4488-e563-4f5b-90ee-4db5a83f7faa} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 0, should be 4: In scope SELECT h3PointDistM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 683, line 684) (in query: SELECT h3PointDistM();) 2025.06.13 15:43:51.064394 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 0, should be 4: In scope SELECT h3PointDistM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:51.184341 [ 5978 ] {1679398c-6f81-4277-845f-e06ceb3f6055} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUUIDOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUUIDOrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 474, line 475) (in query: SELECT dictGetUUIDOrDefault(-1);) 2025.06.13 15:43:51.193178 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUUIDOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUUIDOrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:51.213614 [ 8431 ] {6ec609db-53d6-4057-b2f1-e2773ed76fe1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 0, should be 4: In scope SELECT h3PointDistRads(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 684, line 685) (in query: SELECT h3PointDistRads();) 2025.06.13 15:43:51.222012 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 0, should be 4: In scope SELECT h3PointDistRads(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:51.296452 [ 5978 ] {e0939c61-4b3a-48ae-8796-007d9b61014d} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictHas: In scope SELECT dictHas(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 475, line 476) (in query: SELECT dictHas(-1);) 2025.06.13 15:43:51.302553 [ 8431 ] {da6120f8-3bc7-4a9f-a75f-516b99b719f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 0, should be 2: In scope SELECT h3ToCenterChild(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 685, line 686) (in query: SELECT h3ToCenterChild();) 2025.06.13 15:43:51.311507 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictHas: In scope SELECT dictHas(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:51.316025 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 0, should be 2: In scope SELECT h3ToCenterChild(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:51.423480 [ 8431 ] {80f59c99-f133-4e27-be04-313d0b0544d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 0, should be 2: In scope SELECT h3ToChildren(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 686, line 687) (in query: SELECT h3ToChildren();) 2025.06.13 15:43:51.427496 [ 5978 ] {0c19bc54-53f0-4269-9f37-c7259655d046} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 1, should be 3: In scope SELECT dictIsIn(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 476, line 477) (in query: SELECT dictIsIn(-1);) 2025.06.13 15:43:51.436712 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 0, should be 2: In scope SELECT h3ToChildren(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:51.438316 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 1, should be 3: In scope SELECT dictIsIn(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:51.706549 [ 8431 ] {df6558e1-4db4-48cf-8ecf-6509f1b9a153} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 0, should be 1: In scope SELECT h3ToGeo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 687, line 688) (in query: SELECT h3ToGeo();) 2025.06.13 15:43:51.714353 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 0, should be 1: In scope SELECT h3ToGeo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:51.719931 [ 5978 ] {7bfa6f4f-997a-464b-b6c7-c16f4c38d134} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 1, should be 0: In scope SELECT displayName(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 477, line 478) (in query: SELECT displayName(-1);) 2025.06.13 15:43:51.732833 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 1, should be 0: In scope SELECT displayName(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:51.809673 [ 8431 ] {1af163cc-a1a6-4a45-95eb-3778f0930366} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 0, should be 1: In scope SELECT h3ToGeoBoundary(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 688, line 689) (in query: SELECT h3ToGeoBoundary();) 2025.06.13 15:43:51.821236 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 0, should be 1: In scope SELECT h3ToGeoBoundary(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:51.832939 [ 5978 ] {21baa44e-69de-453a-b672-e08e9f9c8bfc} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 1, should be 2: In scope SELECT distanceL1(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 478, line 479) (in query: SELECT distanceL1(-1);) 2025.06.13 15:43:51.841841 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 1, should be 2: In scope SELECT distanceL1(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:51.990672 [ 8431 ] {def43cde-fe5a-4fd2-9ac1-a67b75e480c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 0, should be 2: In scope SELECT h3ToParent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 689, line 690) (in query: SELECT h3ToParent();) 2025.06.13 15:43:52.026280 [ 5978 ] {b3d7059c-3a31-4390-b0b5-32d775646dca} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 1, should be 2: In scope SELECT distanceL2(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 479, line 480) (in query: SELECT distanceL2(-1);) 2025.06.13 15:43:52.028277 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 0, should be 2: In scope SELECT h3ToParent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:52.034124 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 1, should be 2: In scope SELECT distanceL2(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:52.114527 [ 8442 ] {fdcb4193-d3c7-4493-b8c9-b78a4da475fd} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float32. Actual Nullable(Nothing): In scope SELECT toFloat32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1362, line 1364) (in query: SELECT toFloat32OrDefault(NULL, NULL);) 2025.06.13 15:43:52.133713 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float32. Actual Nullable(Nothing): In scope SELECT toFloat32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:43:52.133674 [ 8431 ] {27338790-3b71-4229-862f-0569288c0403} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 0, should be 1: In scope SELECT h3ToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 690, line 691) (in query: SELECT h3ToString();) 2025.06.13 15:43:52.157477 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 0, should be 1: In scope SELECT h3ToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:52.198738 [ 5978 ] {009df03a-bd5e-488f-b5da-a620b8d6dd15} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 1, should be 2: In scope SELECT distanceL2Squared(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 480, line 481) (in query: SELECT distanceL2Squared(-1);) 2025.06.13 15:43:52.210852 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 1, should be 2: In scope SELECT distanceL2Squared(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:52.286469 [ 8431 ] {2c8ef1b7-236c-4938-b570-bd3f4f984bf1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 0, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 691, line 692) (in query: SELECT h3UnidirectionalEdgeIsValid();) 2025.06.13 15:43:52.293727 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 0, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:52.400154 [ 5978 ] {2c98884a-f4ce-4993-9e8b-41a19a54e913} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 1, should be 2: In scope SELECT distanceLinf(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 481, line 482) (in query: SELECT distanceLinf(-1);) 2025.06.13 15:43:52.410525 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 1, should be 2: In scope SELECT distanceLinf(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:52.435710 [ 8431 ] {4a528803-17a1-4c77-970b-382a66838d36} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 0, should be 2: In scope SELECT h3kRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 692, line 693) (in query: SELECT h3kRing();) 2025.06.13 15:43:52.458683 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 0, should be 2: In scope SELECT h3kRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:52.517898 [ 5978 ] {9ee28137-5e9a-4bc4-8e67-ec89d0d906bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 1, should be 3: In scope SELECT distanceLp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 482, line 483) (in query: SELECT distanceLp(-1);) 2025.06.13 15:43:52.538482 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 1, should be 3: In scope SELECT distanceLp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:52.661161 [ 5978 ] {b96d3cba-2679-49a2-9cbd-abf540c7e148} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument for aggregate function distinctDynamicTypes. Expected type Dynamic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 483, line 484) (in query: SELECT distinctDynamicTypes(-1);) 2025.06.13 15:43:52.668750 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument for aggregate function distinctDynamicTypes. Expected type Dynamic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:52.808356 [ 8431 ] {8afd5795-f987-452e-9966-82fad87db018} executeQuery: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 0, should be 2: In scope SELECT has(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 694, line 695) (in query: SELECT has();) 2025.06.13 15:43:52.814004 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 0, should be 2: In scope SELECT has(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:52.848323 [ 5978 ] {86f3b6a1-f06d-4124-9449-c3d92c4cae04} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument for aggregate function distinctJSONPaths. Expected type JSON. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 484, line 485) (in query: SELECT distinctJSONPaths(-1);) 2025.06.13 15:43:52.855859 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument for aggregate function distinctJSONPaths. Expected type JSON. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:52.916640 [ 8431 ] {e7f7475a-da91-405d-85ee-1aa666f58929} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 0, should be 2: In scope SELECT hasAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 695, line 696) (in query: SELECT hasAll();) 2025.06.13 15:43:52.922938 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 0, should be 2: In scope SELECT hasAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:52.935915 [ 8442 ] {706fbc44-20a3-4f25-9c3a-6f16e6d12e2d} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float64. Actual Nullable(Nothing): In scope SELECT toFloat64OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1366, line 1368) (in query: SELECT toFloat64OrDefault(NULL, NULL);) 2025.06.13 15:43:52.960680 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float64. Actual Nullable(Nothing): In scope SELECT toFloat64OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:43:52.992606 [ 5978 ] {9ea17d3e-4476-4047-b37a-603a9dad36e1} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument for aggregate function distinctJSONPathsAndTypes. Expected type JSON. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 485, line 486) (in query: SELECT distinctJSONPathsAndTypes(-1);) 2025.06.13 15:43:53.011443 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument for aggregate function distinctJSONPathsAndTypes. Expected type JSON. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:53.047989 [ 8431 ] {9639710c-8939-4fb3-b6fe-6ad65b91b95f} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 0, should be 2: In scope SELECT hasAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 696, line 697) (in query: SELECT hasAny();) 2025.06.13 15:43:53.062527 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 0, should be 2: In scope SELECT hasAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:53.086082 [ 5978 ] {b9426375-f03b-4d74-80dd-aefa7785f250} executeQuery: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 1, should be 2: In scope SELECT divide(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 486, line 487) (in query: SELECT divide(-1);) 2025.06.13 15:43:53.146128 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 1, should be 2: In scope SELECT divide(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:53.367723 [ 8431 ] {62ef48b5-1c74-4d96-bc20-68cc5fac7577} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function hasColumnInTable: In scope SELECT hasColumnInTable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 697, line 698) (in query: SELECT hasColumnInTable();) 2025.06.13 15:43:53.374794 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function hasColumnInTable: In scope SELECT hasColumnInTable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:53.422417 [ 5978 ] {1aee4fb4-bad8-4999-b22c-36528c58a345} executeQuery: Code: 42. DB::Exception: Number of arguments for function divideDecimal does not match: 2 or 3 expected: In scope SELECT divideDecimal(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 487, line 488) (in query: SELECT divideDecimal(-1);) 2025.06.13 15:43:53.429635 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divideDecimal does not match: 2 or 3 expected: In scope SELECT divideDecimal(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:53.466893 [ 8431 ] {f1271a15-4319-405c-82e4-3bb2fee29ad6} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 0, should be 2: In scope SELECT hasSubsequence(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 698, line 699) (in query: SELECT hasSubsequence();) 2025.06.13 15:43:53.479627 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 0, should be 2: In scope SELECT hasSubsequence(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:53.571820 [ 5978 ] {f69d36bd-87c1-4072-b2d3-4d936294e9ee} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function domain: In scope SELECT domain(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 488, line 489) (in query: SELECT domain(-1);) 2025.06.13 15:43:53.577911 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function domain: In scope SELECT domain(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:53.643045 [ 8431 ] {31eafafd-204b-40da-92e6-f51debe75e33} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 699, line 700) (in query: SELECT hasSubsequenceCaseInsensitive();) 2025.06.13 15:43:53.656316 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:53.683441 [ 5978 ] {792033e5-eef3-4fdd-b477-158ebbdf22de} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function domainRFC: In scope SELECT domainRFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 489, line 490) (in query: SELECT domainRFC(-1);) 2025.06.13 15:43:53.736633 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function domainRFC: In scope SELECT domainRFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:53.757231 [ 8431 ] {9a87c7c5-d07a-42cd-bb9a-1dad67bd8db6} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 700, line 701) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8();) 2025.06.13 15:43:53.779024 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:53.869210 [ 5978 ] {081cb026-4b87-495a-9e2d-4516b680b5c6} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function domainWithoutWWW: In scope SELECT domainWithoutWWW(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 490, line 491) (in query: SELECT domainWithoutWWW(-1);) 2025.06.13 15:43:53.879051 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function domainWithoutWWW: In scope SELECT domainWithoutWWW(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:53.947459 [ 8431 ] {ea8c249a-1feb-47d5-ba9a-c64a0336a651} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 701, line 702) (in query: SELECT hasSubsequenceUTF8();) 2025.06.13 15:43:53.953812 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:53.996594 [ 5978 ] {6f17ac3f-e26d-4166-ab2f-986cb1ad13d4} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function domainWithoutWWWRFC: In scope SELECT domainWithoutWWWRFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 491, line 492) (in query: SELECT domainWithoutWWWRFC(-1);) 2025.06.13 15:43:54.013969 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function domainWithoutWWWRFC: In scope SELECT domainWithoutWWWRFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:54.059787 [ 8431 ] {8ef0da61-b5f2-486a-8eae-d815a423302e} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 0, should be 2: In scope SELECT hasSubstr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 702, line 703) (in query: SELECT hasSubstr();) 2025.06.13 15:43:54.067590 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 0, should be 2: In scope SELECT hasSubstr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:54.078147 [ 8442 ] {02d4e28c-212b-4ff9-8099-c3702394df85} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv4. Actual Nullable(Nothing): In scope SELECT toIPv4OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1371, line 1373) (in query: SELECT toIPv4OrDefault(NULL, NULL);) 2025.06.13 15:43:54.084443 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv4. Actual Nullable(Nothing): In scope SELECT toIPv4OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:43:54.103308 [ 5978 ] {1a96a10f-cbc6-469c-a9da-e0a99e5e0a3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 1, should be 2: In scope SELECT dotProduct(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 492, line 493) (in query: SELECT dotProduct(-1);) 2025.06.13 15:43:54.123544 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 1, should be 2: In scope SELECT dotProduct(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:54.360435 [ 8431 ] {daa1c9e8-ed4f-436f-b8ef-564d5565f896} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 0, should be 2: In scope SELECT hasToken(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 704, line 705) (in query: SELECT hasToken();) 2025.06.13 15:43:54.381556 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 0, should be 2: In scope SELECT hasToken(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:54.473503 [ 5978 ] {90dc1238-7e4e-4b2a-b112-bca0d647c297} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 1, should be 2: In scope SELECT dynamicElement(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 494, line 495) (in query: SELECT dynamicElement(-1);) 2025.06.13 15:43:54.496702 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 1, should be 2: In scope SELECT dynamicElement(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:54.558248 [ 8431 ] {7b78e200-9859-48de-991b-6ea2d6f4db03} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT hasTokenCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 705, line 706) (in query: SELECT hasTokenCaseInsensitive();) 2025.06.13 15:43:54.578367 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT hasTokenCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:54.606409 [ 5978 ] {7992f4fc-e5de-45f4-94c9-ab8fd7396a3a} executeQuery: Code: 43. DB::Exception: First argument for function dynamicType must be Dynamic, got Int8 instead: In scope SELECT dynamicType(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 495, line 496) (in query: SELECT dynamicType(-1);) 2025.06.13 15:43:54.618914 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function dynamicType must be Dynamic, got Int8 instead: In scope SELECT dynamicType(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:54.669372 [ 8431 ] {57a81650-ad39-44b0-afe0-568a30b10739} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 0, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 706, line 707) (in query: SELECT hasTokenCaseInsensitiveOrNull();) 2025.06.13 15:43:54.681998 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 0, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:54.697974 [ 5978 ] {228fdb7d-fe97-432b-983d-bd8c559f682c} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 1, should be 0: In scope SELECT e(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 496, line 497) (in query: SELECT e(-1);) 2025.06.13 15:43:54.721518 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 1, should be 0: In scope SELECT e(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:54.772452 [ 8442 ] {10efabf8-28b7-4d75-82a9-de0849f4e886} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv6. Actual Nullable(Nothing): In scope SELECT toIPv6OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1375, line 1377) (in query: SELECT toIPv6OrDefault(NULL, NULL);) 2025.06.13 15:43:54.776386 [ 8431 ] {124f91eb-2cbc-4884-8020-6afceaf35848} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 0, should be 2: In scope SELECT hasTokenOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 707, line 708) (in query: SELECT hasTokenOrNull();) 2025.06.13 15:43:54.786014 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv6. Actual Nullable(Nothing): In scope SELECT toIPv6OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:43:54.787558 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 0, should be 2: In scope SELECT hasTokenOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:54.930455 [ 5978 ] {546fb7c6-1f9a-4527-8711-676c13489852} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 1, should be 2: In scope SELECT editDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 497, line 498) (in query: SELECT editDistance(-1);) 2025.06.13 15:43:54.937029 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 1, should be 2: In scope SELECT editDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:55.025380 [ 8431 ] {42323bf2-d124-4e87-af4a-5fd7433232b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 0, should be 1: In scope SELECT hex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 708, line 709) (in query: SELECT hex();) 2025.06.13 15:43:55.040377 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 0, should be 1: In scope SELECT hex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:55.065783 [ 5978 ] {08c9e0e5-3b46-420c-bb82-bbe8a307b5cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 1, should be 2: In scope SELECT editDistanceUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 498, line 499) (in query: SELECT editDistanceUTF8(-1);) 2025.06.13 15:43:55.090169 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 1, should be 2: In scope SELECT editDistanceUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:55.199177 [ 8431 ] {234ef061-6261-424c-b0d9-6114d2d1b851} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 0, should be 2: In scope SELECT hilbertDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 709, line 710) (in query: SELECT hilbertDecode();) 2025.06.13 15:43:55.227946 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 0, should be 2: In scope SELECT hilbertDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:55.245843 [ 5978 ] {3fabf37b-0fce-4753-94de-6b71a7a8202b} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function empty: In scope SELECT empty(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 499, line 500) (in query: SELECT empty(-1);) 2025.06.13 15:43:55.267250 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function empty: In scope SELECT empty(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:55.306259 [ 8431 ] {e78bd459-4e91-4656-ad87-ea2827a30d50} executeQuery: Code: 35. DB::Exception: At least one UInt argument is required for function hilbertEncode: In scope SELECT hilbertEncode(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 710, line 711) (in query: SELECT hilbertEncode();) 2025.06.13 15:43:55.312846 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: At least one UInt argument is required for function hilbertEncode: In scope SELECT hilbertEncode(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:43:55.375720 [ 5978 ] {be59d405-ab6d-4325-a987-beaa96faf2a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 1, should be 0: In scope SELECT emptyArrayDate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 500, line 501) (in query: SELECT emptyArrayDate(-1);) 2025.06.13 15:43:55.382361 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 1, should be 0: In scope SELECT emptyArrayDate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:55.412616 [ 8431 ] {f91830c7-ae99-46bd-a92e-c11276e7ef2e} executeQuery: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 711, line 712) (in query: SELECT histogram();) 2025.06.13 15:43:55.427984 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:55.576246 [ 5978 ] {63e2f5bd-0beb-48d3-80a0-6320feaa00dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 1, should be 0: In scope SELECT emptyArrayDateTime(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 501, line 502) (in query: SELECT emptyArrayDateTime(-1);) 2025.06.13 15:43:55.587673 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 1, should be 0: In scope SELECT emptyArrayDateTime(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:55.756218 [ 5978 ] {87142760-301e-42da-8a1c-e703c19e4160} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayFloat32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 502, line 503) (in query: SELECT emptyArrayFloat32(-1);) 2025.06.13 15:43:55.794800 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayFloat32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:55.859640 [ 8431 ] {a0f1a4a2-c0e7-4710-a768-379fb45023d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function hop doesn't match: passed 0, should be 3 or 4: In scope SELECT hop(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 713, line 714) (in query: SELECT hop();) 2025.06.13 15:43:55.897826 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hop doesn't match: passed 0, should be 3 or 4: In scope SELECT hop(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:55.898244 [ 8442 ] {b88e1b7f-12eb-4e3f-bd3e-32e0abd733e1} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int128. Actual Nullable(Nothing): In scope SELECT toInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1381, line 1383) (in query: SELECT toInt128OrDefault(NULL, NULL);) 2025.06.13 15:43:55.937734 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int128. Actual Nullable(Nothing): In scope SELECT toInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:43:55.943572 [ 5978 ] {16e1417a-3e0f-4056-aa68-fb9dd9b2ebd2} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayFloat64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 503, line 504) (in query: SELECT emptyArrayFloat64(-1);) 2025.06.13 15:43:55.950972 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayFloat64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:55.993629 [ 8431 ] {e79f0fc2-4307-4839-afea-6cbfa66d56ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function hopEnd doesn't match: passed 0, should be 3 or 4: In scope SELECT hopEnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 714, line 715) (in query: SELECT hopEnd();) 2025.06.13 15:43:56.003412 [ 8432 ] {6d435bb2-0d93-4a4d-8ea7-05f42c9807d9} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33880) (comment: 02720_row_policy_column_with_dots.sql) (query 1, line 1) (in query: CREATE TABLE IF NOT EXISTS table_with_dot_column (`date` Date, `regular_column` String, `other_column.2` String) ENGINE = MergeTree ORDER BY date SETTINGS index_granularity = 63044, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.8346320390701294, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 112613479, compact_parts_max_bytes_to_buffer = 271414830, compact_parts_max_granules_to_buffer = 136, compact_parts_merge_max_bytes_to_prefetch_part = 30006989, merge_max_block_size = 20331, old_parts_lifetime = 100., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6235228156, index_granularity_bytes = 28466872, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 93, 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 = 87998, primary_key_compress_block_size = 16180, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:56.018533 [ 8432 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:56.025918 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hopEnd doesn't match: passed 0, should be 3 or 4: In scope SELECT hopEnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:56.049576 [ 5978 ] {89542001-9a66-404c-bef6-cd3292035ee4} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt16(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 504, line 505) (in query: SELECT emptyArrayInt16(-1);) 2025.06.13 15:43:56.065608 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt16(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:56.147897 [ 8431 ] {1840b2da-c3b3-4a0e-883c-4285ae2acec8} executeQuery: Code: 42. DB::Exception: Number of arguments for function hopStart doesn't match: passed 0, should be 3 or 4: In scope SELECT hopStart(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 715, line 716) (in query: SELECT hopStart();) 2025.06.13 15:43:56.165798 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hopStart doesn't match: passed 0, should be 3 or 4: In scope SELECT hopStart(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:56.179600 [ 5978 ] {5a095ffa-375a-4479-88b4-b6ababde1737} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 505, line 506) (in query: SELECT emptyArrayInt32(-1);) 2025.06.13 15:43:56.192503 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:56.287914 [ 5978 ] {c2fb09b0-495d-4f04-9123-728409424403} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 506, line 507) (in query: SELECT emptyArrayInt64(-1);) 2025.06.13 15:43:56.308140 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:56.425075 [ 5978 ] {1c842ec3-d0bd-4507-bedb-c707f4bbad65} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 507, line 508) (in query: SELECT emptyArrayInt8(-1);) 2025.06.13 15:43:56.431013 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayInt8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:56.535738 [ 5978 ] {1ddb1e6e-edeb-49a3-9980-e6366e1961ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 1, should be 0: In scope SELECT emptyArrayString(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 508, line 509) (in query: SELECT emptyArrayString(-1);) 2025.06.13 15:43:56.555422 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 1, should be 0: In scope SELECT emptyArrayString(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:56.643471 [ 8442 ] {35e975e5-ca40-487d-b773-71c4306a00ed} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int16. Actual Nullable(Nothing): In scope SELECT toInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1385, line 1387) (in query: SELECT toInt16OrDefault(NULL, NULL);) 2025.06.13 15:43:56.648598 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int16. Actual Nullable(Nothing): In scope SELECT toInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:43:56.756310 [ 8431 ] {aa1e7fa6-80de-4e8f-ab7f-9e2ad4d8849c} executeQuery: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 0, should be 2: In scope SELECT hypot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 718, line 719) (in query: SELECT hypot();) 2025.06.13 15:43:56.760689 [ 5978 ] {00df7690-8fc2-404c-b4a5-6638232c0c96} executeQuery: Code: 43. DB::Exception: Argument for function emptyArrayToSingle must be array.: In scope SELECT emptyArrayToSingle(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 509, line 510) (in query: SELECT emptyArrayToSingle(-1);) 2025.06.13 15:43:56.762807 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 0, should be 2: In scope SELECT hypot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:56.766583 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function emptyArrayToSingle must be array.: In scope SELECT emptyArrayToSingle(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:56.844025 [ 8431 ] {cddb19be-5dcd-49da-baf8-47c99a668a6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergBucket doesn't match: passed 0, should be 2: In scope SELECT icebergBucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 719, line 720) (in query: SELECT icebergBucket();) 2025.06.13 15:43:56.849035 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergBucket doesn't match: passed 0, should be 2: In scope SELECT icebergBucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:56.854205 [ 5978 ] {277671ce-5abb-4e41-8337-d3a55bb8c8a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt16(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 510, line 511) (in query: SELECT emptyArrayUInt16(-1);) 2025.06.13 15:43:56.859389 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt16(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:57.006945 [ 8431 ] {54ad0dcd-e77f-48cb-b08f-971b60e642dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergHash doesn't match: passed 0, should be 1: In scope SELECT icebergHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 720, line 721) (in query: SELECT icebergHash();) 2025.06.13 15:43:57.020017 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergHash doesn't match: passed 0, should be 1: In scope SELECT icebergHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:57.060997 [ 5978 ] {aa7fdaba-4803-430a-8961-135e386e8af6} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 511, line 512) (in query: SELECT emptyArrayUInt32(-1);) 2025.06.13 15:43:57.066910 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:57.148093 [ 18510 ] {ce1d8c08-611f-42f2-aaf2-c2ba2590fa31} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33898) (comment: 02097_polygon_dictionary_store_key.sql) (query 2, line 2) (in query: CREATE TABLE polygons_test_table ( key Array(Array(Array(Tuple(Float64, Float64)))), name String ) ENGINE = TinyLog;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:57.159074 [ 18510 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:43:57.177077 [ 8431 ] {f8e734c9-5802-44e4-80af-b82b4d27d9e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 0, should be 2: In scope SELECT icebergTruncate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 721, line 722) (in query: SELECT icebergTruncate();) 2025.06.13 15:43:57.209225 [ 5978 ] {37a452e6-d317-48e3-b237-4a7deb6e0aed} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 512, line 513) (in query: SELECT emptyArrayUInt64(-1);) 2025.06.13 15:43:57.210920 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 0, should be 2: In scope SELECT icebergTruncate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:57.237912 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:57.320206 [ 8442 ] {f4df962d-4ec2-4fb9-88f6-7ec4b6a53f49} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int256. Actual Nullable(Nothing): In scope SELECT toInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1389, line 1391) (in query: SELECT toInt256OrDefault(NULL, NULL);) 2025.06.13 15:43:57.328424 [ 8431 ] {540e140e-c73a-4e3c-852d-169dc1613b34} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 0, should be 1: In scope SELECT identity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 722, line 723) (in query: SELECT identity();) 2025.06.13 15:43:57.331114 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int256. Actual Nullable(Nothing): In scope SELECT toInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:43:57.334538 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 0, should be 1: In scope SELECT identity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:57.359807 [ 5978 ] {e3672b4a-726e-4546-ad08-7b2c240ce0a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 513, line 514) (in query: SELECT emptyArrayUInt8(-1);) 2025.06.13 15:43:57.370324 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 1, should be 0: In scope SELECT emptyArrayUInt8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:57.448987 [ 8431 ] {2ba36c99-b93a-4e9b-bc8a-6c16cba2fda0} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 0, should be 1: In scope SELECT idnaDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 723, line 724) (in query: SELECT idnaDecode();) 2025.06.13 15:43:57.456475 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 0, should be 1: In scope SELECT idnaDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:57.524678 [ 5978 ] {61ee2c39-ab94-4cbf-8322-4c3ab2b76d8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 1, should be 0: In scope SELECT enabledProfiles(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 514, line 515) (in query: SELECT enabledProfiles(-1);) 2025.06.13 15:43:57.530553 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 1, should be 0: In scope SELECT enabledProfiles(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:57.565009 [ 8431 ] {4aca354d-b39a-44fb-ab8e-f59deaa0f482} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 0, should be 1: In scope SELECT idnaEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 724, line 725) (in query: SELECT idnaEncode();) 2025.06.13 15:43:57.592062 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 0, should be 1: In scope SELECT idnaEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:57.659558 [ 5978 ] {cc1c87f7-b3c5-4643-8f27-4ff2def92703} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 1, should be 0: In scope SELECT enabledRoles(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 515, line 516) (in query: SELECT enabledRoles(-1);) 2025.06.13 15:43:57.668665 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 1, should be 0: In scope SELECT enabledRoles(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:57.703903 [ 8431 ] {9561aa76-7939-48c4-8134-d3add538e9bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 0, should be 3: In scope SELECT if(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 725, line 726) (in query: SELECT if();) 2025.06.13 15:43:57.709725 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 0, should be 3: In scope SELECT if(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:57.721282 [ 5110 ] {d3c1c081-7739-4e5f-813c-2bdfb9a59f76} executeQuery: Code: 36. DB::Exception: Lambda lambda(tuple(1), 1) argument is not identifier. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33936) (comment: 03392_inconsistent_formatting_of_lambda.sql) (query 1, line 1) (in query: SELECT lambda(tuple(1), 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9e507 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9b796 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba1716 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:43:57.732007 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: Lambda lambda(tuple(1), 1) argument is not identifier. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9e507 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9b796 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba1716 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:43:57.736568 [ 5978 ] {afdb4126-537b-4ed6-8c34-2e9dd917f13c} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function encodeURLComponent: In scope SELECT encodeURLComponent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 516, line 517) (in query: SELECT encodeURLComponent(-1);) 2025.06.13 15:43:57.742746 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function encodeURLComponent: In scope SELECT encodeURLComponent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:57.775079 [ 8431 ] {9f1c0e32-71c5-4501-850e-9e75315c3575} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 0, should be 2: In scope SELECT ifNotFinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 726, line 727) (in query: SELECT ifNotFinite();) 2025.06.13 15:43:57.780886 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 0, should be 2: In scope SELECT ifNotFinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:57.806863 [ 5110 ] {45ae9a27-bf02-44bb-8c39-a5caa737d73b} executeQuery: Code: 36. DB::Exception: Lambda lambda((1, 2), materialize(1) + x) argument is not identifier. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33936) (comment: 03392_inconsistent_formatting_of_lambda.sql) (query 2, line 2) (in query: SELECT lambda(tuple(1, 2), materialize(1) + x);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9e507 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9b796 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba1716 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:43:57.814575 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: Lambda lambda((1, 2), materialize(1) + x) argument is not identifier. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:648: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9e507 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:588: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9b796 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:339: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cba1716 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a9c5 9. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9feba 10. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002cb9a480 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000002cb99cdc 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63d80 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:43:57.850326 [ 5978 ] {88d65f6d-1dc7-42c5-b838-b96fc933b6c0} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function encodeURLFormComponent: In scope SELECT encodeURLFormComponent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 517, line 518) (in query: SELECT encodeURLFormComponent(-1);) 2025.06.13 15:43:57.865107 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function encodeURLFormComponent: In scope SELECT encodeURLFormComponent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:57.917719 [ 8431 ] {d947b175-c296-4caa-9469-daf1be3e869a} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 0, should be 2: In scope SELECT ifNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 727, line 728) (in query: SELECT ifNull();) 2025.06.13 15:43:57.935132 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 0, should be 2: In scope SELECT ifNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:58.013239 [ 8442 ] {53780c3b-c9a4-439a-ae6a-92d56dd8f9c4} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int32. Actual Nullable(Nothing): In scope SELECT toInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1393, line 1395) (in query: SELECT toInt32OrDefault(NULL, NULL);) 2025.06.13 15:43:58.020351 [ 5978 ] {4510d154-89aa-491f-86ea-7d88c7bd25b1} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function encodeXMLComponent: In scope SELECT encodeXMLComponent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 518, line 519) (in query: SELECT encodeXMLComponent(-1);) 2025.06.13 15:43:58.025615 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int32. Actual Nullable(Nothing): In scope SELECT toInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:43:58.048017 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function encodeXMLComponent: In scope SELECT encodeXMLComponent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:58.124066 [ 5978 ] {4559aa8b-97a5-46bf-88db-4cf2b0679e06} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT encrypt(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 519, line 520) (in query: SELECT encrypt(-1);) 2025.06.13 15:43:58.129837 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT encrypt(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:58.188952 [ 8431 ] {62eadabe-1186-4e90-9108-08869e12dadd} executeQuery: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 0, should be 2: In scope SELECT ilike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 729, line 730) (in query: SELECT ilike();) 2025.06.13 15:43:58.197805 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 0, should be 2: In scope SELECT ilike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:58.218941 [ 5978 ] {dc26e1ad-78b1-4d3c-b9aa-4fbbec308482} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 1, should be 2: In scope SELECT endsWith(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 520, line 521) (in query: SELECT endsWith(-1);) 2025.06.13 15:43:58.238210 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 1, should be 2: In scope SELECT endsWith(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:58.300529 [ 8431 ] {77e55385-3032-4ca3-81d6-4fdc4b114ec1} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 730, line 731) (in query: SELECT in();) 2025.06.13 15:43:58.317928 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:58.349690 [ 5978 ] {68430674-4d95-4d69-a6ce-193cad6e9410} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 1, should be 2: In scope SELECT endsWithUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 521, line 522) (in query: SELECT endsWithUTF8(-1);) 2025.06.13 15:43:58.376325 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 1, should be 2: In scope SELECT endsWithUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:58.462591 [ 8431 ] {f78972db-392e-4479-b9f2-28d609cc58d3} executeQuery: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 731, line 732) (in query: SELECT inIgnoreSet();) 2025.06.13 15:43:58.467181 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:58.611625 [ 8442 ] {dd1e4612-5e32-4251-af26-bff711554b1a} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int64. Actual Nullable(Nothing): In scope SELECT toInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1397, line 1399) (in query: SELECT toInt64OrDefault(NULL, NULL);) 2025.06.13 15:43:58.620445 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int64. Actual Nullable(Nothing): In scope SELECT toInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:43:58.724797 [ 5978 ] {69b4d81f-e497-49f9-ba50-5e6325cd90db} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 1, should be 2: In scope SELECT equals(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 523, line 524) (in query: SELECT equals(-1);) 2025.06.13 15:43:58.731224 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 1, should be 2: In scope SELECT equals(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:58.768214 [ 8431 ] {370126aa-719d-4065-81a0-68e1c823d43a} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 0, should be 2: In scope SELECT indexOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 733, line 734) (in query: SELECT indexOf();) 2025.06.13 15:43:58.774279 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 0, should be 2: In scope SELECT indexOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:58.877608 [ 8431 ] {32b6559e-d560-417a-b910-a1edd7256d60} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 0, should be 2: In scope SELECT indexOfAssumeSorted(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 734, line 735) (in query: SELECT indexOfAssumeSorted();) 2025.06.13 15:43:58.884812 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 0, should be 2: In scope SELECT indexOfAssumeSorted(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:59.039077 [ 8431 ] {ad1fbf8c-e8c0-42b7-b6e0-11c91cdca04f} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 0, should be 1: In scope SELECT initcap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 735, line 736) (in query: SELECT initcap();) 2025.06.13 15:43:59.054264 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 0, should be 1: In scope SELECT initcap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:59.161347 [ 8431 ] {daa9a23b-db70-49fa-8f9e-f7e26599b1b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 0, should be 1: In scope SELECT initcapUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 736, line 737) (in query: SELECT initcapUTF8();) 2025.06.13 15:43:59.168003 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 0, should be 1: In scope SELECT initcapUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:43:59.248223 [ 8442 ] {43d8acbe-a2b0-4dc0-a467-442e9972ce26} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int8. Actual Nullable(Nothing): In scope SELECT toInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1401, line 1403) (in query: SELECT toInt8OrDefault(NULL, NULL);) 2025.06.13 15:43:59.259031 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int8. Actual Nullable(Nothing): In scope SELECT toInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:43:59.585852 [ 5978 ] {627031df-c203-4214-aacf-bce2e43cbb9e} executeQuery: Code: 43. DB::Exception: Argument for function evalMLMethod must have type AggregateFunction - state of aggregate function.: In scope SELECT evalMLMethod(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 528, line 529) (in query: SELECT evalMLMethod(-1);) 2025.06.13 15:43:59.650815 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function evalMLMethod must have type AggregateFunction - state of aggregate function.: In scope SELECT evalMLMethod(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:43:59.654968 [ 9642 ] {c422adc4-a01b-4f6e-bd32-c9a6275e1f01} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00 million, current rows: 111.22 billion. (TOO_MANY_ROWS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47514) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 111222333444 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:626: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000003224e174 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:552: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003224c117 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003224a419 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:43:59.659940 [ 9642 ] {c422adc4-a01b-4f6e-bd32-c9a6275e1f01} DynamicQueryHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00 million, current rows: 111.22 billion. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:626: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000003224e174 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:552: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003224c117 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003224a419 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:43:59.940189 [ 8431 ] {5d6e957f-8bfd-4cc9-b071-e7f361ccdca2} executeQuery: Code: 42. DB::Exception: Number of arguments for function initializeAggregation doesn't match: passed 0, should be at least 2.: In scope SELECT initializeAggregation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 741, line 742) (in query: SELECT initializeAggregation();) 2025.06.13 15:43:59.957524 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initializeAggregation doesn't match: passed 0, should be at least 2.: In scope SELECT initializeAggregation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:00.093384 [ 18510 ] {e495a980-e0fb-4b49-87e6-9f95d4a0b76b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47526) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:00.101143 [ 18510 ] {e495a980-e0fb-4b49-87e6-9f95d4a0b76b} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:00.116365 [ 8431 ] {904e7096-f60f-493e-a008-1c072aa9753d} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT instr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 742, line 743) (in query: SELECT instr();) 2025.06.13 15:44:00.131302 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT instr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:00.188542 [ 8431 ] {a8de1e21-42e1-4d43-b666-e398f72ad43c} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 0, should be 2: In scope SELECT intDiv(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 743, line 744) (in query: SELECT intDiv();) 2025.06.13 15:44:00.193819 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 0, should be 2: In scope SELECT intDiv(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:00.244635 [ 5978 ] {30f1e486-08c2-4698-b491-848cf2adf5a7} executeQuery: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 532, line 533) (in query: SELECT exponentialMovingAverage(-1);) 2025.06.13 15:44:00.251595 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:00.291616 [ 8431 ] {a7d6ff06-451e-46f0-abd1-def951035749} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 0, should be 2: In scope SELECT intDivOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 744, line 745) (in query: SELECT intDivOrZero();) 2025.06.13 15:44:00.298505 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 0, should be 2: In scope SELECT intDivOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:00.314814 [ 5978 ] {5e152b3f-1290-4ee8-8790-39e5efbe79bb} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 533, line 534) (in query: SELECT exponentialTimeDecayedAvg(-1);) 2025.06.13 15:44:00.332143 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:00.368571 [ 3931 ] {36d2efec-40df-4782-925f-c559efc30b3c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47528) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:00.373839 [ 3931 ] {36d2efec-40df-4782-925f-c559efc30b3c} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:00.486808 [ 8431 ] {5e32799d-7e59-4fa8-aafd-135510757976} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 0, should be 1: In scope SELECT intExp10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 745, line 746) (in query: SELECT intExp10();) 2025.06.13 15:44:00.496407 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 0, should be 1: In scope SELECT intExp10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:00.589086 [ 5978 ] {2dee30d5-b376-4497-847d-63bbec2cf69b} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 534, line 535) (in query: SELECT exponentialTimeDecayedCount(-1);) 2025.06.13 15:44:00.598434 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:00.698480 [ 5978 ] {07a4cc89-ca41-4839-ab9b-70ac8222d23e} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 535, line 536) (in query: SELECT exponentialTimeDecayedMax(-1);) 2025.06.13 15:44:00.722705 [ 8431 ] {cb93ae2f-3aa5-4a09-b31c-8ff229436436} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 0, should be 1: In scope SELECT intExp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 746, line 747) (in query: SELECT intExp2();) 2025.06.13 15:44:00.724371 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:00.728713 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 0, should be 1: In scope SELECT intExp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:00.855858 [ 5978 ] {7ef991cc-ec5c-4c61-b9ac-147f4b7a4777} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 536, line 537) (in query: SELECT exponentialTimeDecayedSum(-1);) 2025.06.13 15:44:00.863232 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:00.867596 [ 8431 ] {e2e6346d-0eb4-4ccc-9b0c-4c0bd5ee92c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 0, should be 1: In scope SELECT intHash32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 747, line 748) (in query: SELECT intHash32();) 2025.06.13 15:44:00.890387 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 0, should be 1: In scope SELECT intHash32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.046179 [ 5163 ] {77536566-d809-4a1e-bcd7-0317fb414140} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47536) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1048577 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:01.053607 [ 5978 ] {33d6bd04-dd6d-48ce-8d81-0c52e7081b46} executeQuery: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 1, should be 2: In scope SELECT extract(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 537, line 538) (in query: SELECT extract(-1);) 2025.06.13 15:44:01.053791 [ 8431 ] {a4ae486d-40b1-4d6f-80e4-be5d25bd1ced} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 0, should be 1: In scope SELECT intHash64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 748, line 749) (in query: SELECT intHash64();) 2025.06.13 15:44:01.060750 [ 5163 ] {77536566-d809-4a1e-bcd7-0317fb414140} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:01.061034 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 1, should be 2: In scope SELECT extract(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.069525 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 0, should be 1: In scope SELECT intHash64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.182074 [ 5978 ] {82ae0807-96f1-4621-9f05-287ca1b60118} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 1, should be 2: In scope SELECT extractAll(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 538, line 539) (in query: SELECT extractAll(-1);) 2025.06.13 15:44:01.185345 [ 8431 ] {376147de-e45d-4828-800f-15355a8a7403} executeQuery: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 749, line 750) (in query: SELECT intervalLengthSum();) 2025.06.13 15:44:01.189051 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 1, should be 2: In scope SELECT extractAll(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.195768 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.277420 [ 5978 ] {c7741596-1e64-4b89-b053-88f541d175e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 1, should be 2: In scope SELECT extractAllGroups(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 539, line 540) (in query: SELECT extractAllGroups(-1);) 2025.06.13 15:44:01.278115 [ 8431 ] {8775435c-b922-4335-9f99-5ce2a8201e67} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 0, should be 1: In scope SELECT isConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 750, line 751) (in query: SELECT isConstant();) 2025.06.13 15:44:01.284016 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 1, should be 2: In scope SELECT extractAllGroups(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.291750 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 0, should be 1: In scope SELECT isConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.376116 [ 8431 ] {28a184ab-2506-43de-a65d-e9b0f2f51639} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDecimalOverflow doesn't match: passed 0, should be 1 or 2.: In scope SELECT isDecimalOverflow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 751, line 752) (in query: SELECT isDecimalOverflow();) 2025.06.13 15:44:01.385167 [ 5978 ] {86cfe422-d1e3-40c9-a3ea-7a94dff00afb} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsHorizontal(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 540, line 541) (in query: SELECT extractAllGroupsHorizontal(-1);) 2025.06.13 15:44:01.392395 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDecimalOverflow doesn't match: passed 0, should be 1 or 2.: In scope SELECT isDecimalOverflow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.395215 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsHorizontal(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.489499 [ 8431 ] {4375ee9d-ce5e-4ba0-a63c-df0d466e5269} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 0, should be 1: In scope SELECT isDynamicElementInSharedData(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 752, line 753) (in query: SELECT isDynamicElementInSharedData();) 2025.06.13 15:44:01.491854 [ 5978 ] {818eb512-3c11-4e36-b82a-7907ce894239} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsVertical(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 541, line 542) (in query: SELECT extractAllGroupsVertical(-1);) 2025.06.13 15:44:01.497649 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 0, should be 1: In scope SELECT isDynamicElementInSharedData(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.514036 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsVertical(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.582330 [ 8431 ] {27df8312-7ccd-422e-9535-1971423e73c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 0, should be 1: In scope SELECT isFinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 753, line 754) (in query: SELECT isFinite();) 2025.06.13 15:44:01.596543 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 0, should be 1: In scope SELECT isFinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.601893 [ 5978 ] {a64af1ac-bbf8-4810-b0ae-7a6e9f6d5788} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 1, should be 2: In scope SELECT extractGroups(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 542, line 543) (in query: SELECT extractGroups(-1);) 2025.06.13 15:44:01.606793 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 1, should be 2: In scope SELECT extractGroups(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.678612 [ 8442 ] {1b13bc95-6e12-40eb-8649-2ea53547d425} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 2, should be 1: In scope SELECT toJSONString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1415, line 1417) (in query: SELECT toJSONString(NULL, NULL);) 2025.06.13 15:44:01.687156 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 2, should be 1: In scope SELECT toJSONString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.707872 [ 8431 ] {7cc04269-2ae1-4be4-aa3a-83e2d4e13508} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 0, should be 2: In scope SELECT isIPAddressInRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 754, line 755) (in query: SELECT isIPAddressInRange();) 2025.06.13 15:44:01.718783 [ 5978 ] {927e470a-1e40-4760-a1e1-c764c9ca2f1a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument data_column. Must be String.: In scope SELECT extractKeyValuePairs(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 543, line 544) (in query: SELECT extractKeyValuePairs(-1);) 2025.06.13 15:44:01.723329 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 0, should be 2: In scope SELECT isIPAddressInRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.732781 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument data_column. Must be String.: In scope SELECT extractKeyValuePairs(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:01.841788 [ 8431 ] {f81e6d3b-4193-4ce6-8842-8f87730f6f16} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 0, should be 1: In scope SELECT isIPv4String(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 755, line 756) (in query: SELECT isIPv4String();) 2025.06.13 15:44:01.846308 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 0, should be 1: In scope SELECT isIPv4String(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.848205 [ 5978 ] {3f049498-d669-4173-aa4b-52b49df0632e} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument data_column. Must be String.: In scope SELECT extractKeyValuePairsWithEscaping(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 544, line 545) (in query: SELECT extractKeyValuePairsWithEscaping(-1);) 2025.06.13 15:44:01.856851 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument data_column. Must be String.: In scope SELECT extractKeyValuePairsWithEscaping(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:01.955593 [ 8431 ] {9fe8bf74-c0bb-418d-bc04-254af2f152ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 0, should be 1: In scope SELECT isIPv6String(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 756, line 757) (in query: SELECT isIPv6String();) 2025.06.13 15:44:01.962832 [ 5978 ] {722b3c5d-893d-464e-9488-2eb2e9fa7f14} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function extractTextFromHTML: In scope SELECT extractTextFromHTML(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 545, line 546) (in query: SELECT extractTextFromHTML(-1);) 2025.06.13 15:44:01.962742 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 0, should be 1: In scope SELECT isIPv6String(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:01.978359 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function extractTextFromHTML: In scope SELECT extractTextFromHTML(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:02.024830 [ 8431 ] {f4cd58ff-e856-4f03-8a45-042387427fbd} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 0, should be 1: In scope SELECT isInfinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 757, line 758) (in query: SELECT isInfinite();) 2025.06.13 15:44:02.033821 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 0, should be 1: In scope SELECT isInfinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:02.053107 [ 5978 ] {7e4d4fe4-9b66-4fb2-b0ab-b814160e54a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 1, should be 2: In scope SELECT extractURLParameter(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 546, line 547) (in query: SELECT extractURLParameter(-1);) 2025.06.13 15:44:02.061585 [ 8442 ] {9c336117-0bd9-4101-a924-bd83376e6cab} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 2, should be 1: In scope SELECT toLowCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1418, line 1420) (in query: SELECT toLowCardinality(NULL, NULL);) 2025.06.13 15:44:02.081436 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 1, should be 2: In scope SELECT extractURLParameter(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:02.090493 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 2, should be 1: In scope SELECT toLowCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:02.105551 [ 8431 ] {c5e32a72-9afb-4a67-ac48-6dd7f272bf21} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 0, should be 1: In scope SELECT isNaN(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 758, line 759) (in query: SELECT isNaN();) 2025.06.13 15:44:02.121038 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 0, should be 1: In scope SELECT isNaN(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:02.142978 [ 5978 ] {8d757f90-c254-4a1c-b44f-4fea78ef8c54} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'extractURLParameterNames'. Expected: String, got: Int8: In scope SELECT extractURLParameterNames(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 547, line 548) (in query: SELECT extractURLParameterNames(-1);) 2025.06.13 15:44:02.151737 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'extractURLParameterNames'. Expected: String, got: Int8: In scope SELECT extractURLParameterNames(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:02.238208 [ 8431 ] {60348f50-b0e3-4dbd-9d0c-3e66d7c74d1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 0, should be 2: In scope SELECT isNotDistinctFrom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 759, line 760) (in query: SELECT isNotDistinctFrom();) 2025.06.13 15:44:02.241820 [ 5978 ] {32c833aa-5ab4-4ff2-83c2-c13d672573dd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'extractURLParameters'. Expected: String, got: Int8: In scope SELECT extractURLParameters(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 548, line 549) (in query: SELECT extractURLParameters(-1);) 2025.06.13 15:44:02.248064 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 0, should be 2: In scope SELECT isNotDistinctFrom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:02.251606 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'URL' to function 'extractURLParameters'. Expected: String, got: Int8: In scope SELECT extractURLParameters(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:02.350717 [ 8431 ] {78ce513f-61de-48ca-b080-d3ccedf83f0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 0, should be 1: In scope SELECT isNotNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 760, line 761) (in query: SELECT isNotNull();) 2025.06.13 15:44:02.358559 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 0, should be 1: In scope SELECT isNotNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:02.495013 [ 8431 ] {1d5b1664-921b-4c14-9b45-72c158bf6d91} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 0, should be 1: In scope SELECT isNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 761, line 762) (in query: SELECT isNull();) 2025.06.13 15:44:02.503481 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 0, should be 1: In scope SELECT isNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:02.576071 [ 8101 ] {719a9b7e-6cda-4594-a161-934eb10ed730} executeQuery: Code: 48. DB::Exception: Function sum does not support RESPECT NULLS. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33864) (comment: 02922_respect_nulls_extensive.sql) (query 32, line 43) (in query: -- Unsupported functions should throw in the server SELECT number, sum (number) RESPECT NULLS over (order by number) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:144: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x000000002b3c5660 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:305: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x000000002b3c3157 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:103: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c2195 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cc50 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:44:02.577680 [ 8431 ] {650883b6-f81f-4466-a61d-d9aab16a1d4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 0, should be 1: In scope SELECT isNullable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 762, line 763) (in query: SELECT isNullable();) 2025.06.13 15:44:02.577755 [ 8442 ] {fb0c6c9c-c1ef-44e8-9aa8-8931064861a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1421, line 1423) (in query: SELECT toModifiedJulianDay(NULL, NULL);) 2025.06.13 15:44:02.582340 [ 8101 ] {} TCPHandler: Code: 48. DB::Exception: Function sum does not support RESPECT NULLS. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:144: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x000000002b3c5660 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:305: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x000000002b3c3157 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:103: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c2195 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cc50 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:44:02.584618 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:02.586110 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 0, should be 1: In scope SELECT isNullable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:02.620539 [ 8101 ] {b8e34c15-4e27-47b1-9a9e-4898aa12c709} executeQuery: Code: 48. DB::Exception: Function avg does not support RESPECT NULLS. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33864) (comment: 02922_respect_nulls_extensive.sql) (query 33, line 45) (in query: SELECT number, avgIf (number) RESPECT NULLS over (order by number) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:144: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x000000002b3c5660 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:305: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x000000002b3c3157 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:103: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c2195 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cc50 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:44:02.625356 [ 8101 ] {} TCPHandler: Code: 48. DB::Exception: Function avg does not support RESPECT NULLS. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:144: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x000000002b3c5660 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:305: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x000000002b3c3157 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:103: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c2195 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cc50 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:44:02.706429 [ 8442 ] {9925ec5a-0346-4533-b22d-b43833e7eee2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1422, line 1424) (in query: SELECT toModifiedJulianDayOrNull(NULL, NULL);) 2025.06.13 15:44:02.721402 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:02.730877 [ 8431 ] {d52f34e1-64c0-4d39-9a15-92e23e886318} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 763, line 764) (in query: SELECT isValidJSON();) 2025.06.13 15:44:02.738210 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:02.799979 [ 8101 ] {95af4ed9-cd3b-4e7e-8c7a-74ea13528403} executeQuery: Code: 48. DB::Exception: Function any_respect_nulls does not support RESPECT NULLS. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33864) (comment: 02922_respect_nulls_extensive.sql) (query 34, line 46) (in query: -- Same for double RESPECT NULLS SELECT number, first_value_respect_nulls (number) RESPECT NULLS over (order by number) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:144: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x000000002b3c5660 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:305: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x000000002b3c3157 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:103: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c2195 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cc50 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:44:02.800393 [ 9636 ] {974e3ba9-2597-4d76-8cdc-d137e4dc5466} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47542) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1048577 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:02.804709 [ 9636 ] {974e3ba9-2597-4d76-8cdc-d137e4dc5466} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:02.806157 [ 8101 ] {} TCPHandler: Code: 48. DB::Exception: Function any_respect_nulls does not support RESPECT NULLS. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:144: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x000000002b3c5660 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:305: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x000000002b3c3157 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:103: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c2195 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cc50 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:44:02.988580 [ 8431 ] {2745d7e2-5564-4076-91e9-87c3680b2907} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 0, should be 1: In scope SELECT isValidUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 764, line 765) (in query: SELECT isValidUTF8();) 2025.06.13 15:44:02.999729 [ 5978 ] {99f7d3e3-a680-4ffd-8a04-b4929398a34a} executeQuery: Code: 48. DB::Exception: file is only implemented for type String: In scope SELECT file(-1). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 552, line 553) (in query: SELECT file(-1);) 2025.06.13 15:44:03.003928 [ 8101 ] {b9b5af1b-4fb6-4fc3-b7d6-433aa8e18c62} executeQuery: Code: 48. DB::Exception: Function anyLast_respect_nulls does not support RESPECT NULLS. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33864) (comment: 02922_respect_nulls_extensive.sql) (query 35, line 48) (in query: SELECT number, last_value_respect_nulls (number) RESPECT NULLS over (order by number) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:144: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x000000002b3c5660 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:305: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x000000002b3c3157 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:103: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c2195 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cc50 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:44:03.004453 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 0, should be 1: In scope SELECT isValidUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:03.010546 [ 8101 ] {} TCPHandler: Code: 48. DB::Exception: Function anyLast_respect_nulls does not support RESPECT NULLS. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:144: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x000000002b3c5660 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:305: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x000000002b3c3157 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:103: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c2195 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3285: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2cc50 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:44:03.071340 [ 8431 ] {44a2c142-ce28-41c3-aeec-b95e635817ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 0, should be 1: In scope SELECT isZeroOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 765, line 766) (in query: SELECT isZeroOrNull();) 2025.06.13 15:44:03.090339 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 0, should be 1: In scope SELECT isZeroOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:03.108879 [ 5978 ] {} TCPHandler: Code: 48. DB::Exception: file is only implemented for type String: In scope SELECT file(-1). (NOT_IMPLEMENTED) 2025.06.13 15:44:03.154764 [ 5978 ] {026a9bb2-fca9-4d29-81ba-f01e1c7b3af9} executeQuery: Code: 43. DB::Exception: Arguments of function filesystemAvailable should be String or FixedString: In scope SELECT filesystemAvailable(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 553, line 554) (in query: SELECT filesystemAvailable(-1);) 2025.06.13 15:44:03.162423 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function filesystemAvailable should be String or FixedString: In scope SELECT filesystemAvailable(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:03.275531 [ 8431 ] {519a16ff-6865-4a02-b4b1-bffcf793e1b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 0, should be 2: In scope SELECT jaroSimilarity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 766, line 767) (in query: SELECT jaroSimilarity();) 2025.06.13 15:44:03.284141 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 0, should be 2: In scope SELECT jaroSimilarity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:03.325422 [ 5978 ] {2a827aef-070a-4316-a7d5-3f890c2d0f49} executeQuery: Code: 43. DB::Exception: Arguments of function filesystemCapacity should be String or FixedString: In scope SELECT filesystemCapacity(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 554, line 555) (in query: SELECT filesystemCapacity(-1);) 2025.06.13 15:44:03.338848 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function filesystemCapacity should be String or FixedString: In scope SELECT filesystemCapacity(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:03.355347 [ 8442 ] {d70aebed-d460-45a3-998b-bba2abb7b726} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 2, should be 1: In scope SELECT toNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1426, line 1428) (in query: SELECT toNullable(NULL, NULL);) 2025.06.13 15:44:03.368817 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 2, should be 1: In scope SELECT toNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:03.375529 [ 8431 ] {a246cd3c-645f-485c-b713-d6a85f9ba237} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 0, should be 2: In scope SELECT jaroWinklerSimilarity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 767, line 768) (in query: SELECT jaroWinklerSimilarity();) 2025.06.13 15:44:03.382799 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 0, should be 2: In scope SELECT jaroWinklerSimilarity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:03.407626 [ 5978 ] {a2feba2b-d6ce-46dc-8ce5-dae68ad6c668} executeQuery: Code: 43. DB::Exception: Arguments of function filesystemUnreserved should be String or FixedString: In scope SELECT filesystemUnreserved(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 555, line 556) (in query: SELECT filesystemUnreserved(-1);) 2025.06.13 15:44:03.416920 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function filesystemUnreserved should be String or FixedString: In scope SELECT filesystemUnreserved(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:03.502879 [ 5978 ] {b9e273eb-c061-49ba-a48a-ac018fd4e52e} executeQuery: Code: 43. DB::Exception: Argument for function 'finalizeAggregation' must have type AggregateFunction - state of aggregate function. Got 'Int8' instead: In scope SELECT finalizeAggregation(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 556, line 557) (in query: SELECT finalizeAggregation(-1);) 2025.06.13 15:44:03.531782 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function 'finalizeAggregation' must have type AggregateFunction - state of aggregate function. Got 'Int8' instead: In scope SELECT finalizeAggregation(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:03.586367 [ 6234 ] {19b7e877-c251-4467-9978-48b6bb05903a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:47558) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1500001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:03.589252 [ 6234 ] {19b7e877-c251-4467-9978-48b6bb05903a} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:03.599042 [ 5978 ] {3ba4cd63-3ee0-4c8f-89ff-4046205e6df8} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function firstLine: In scope SELECT firstLine(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 557, line 558) (in query: SELECT firstLine(-1);) 2025.06.13 15:44:03.622296 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function firstLine: In scope SELECT firstLine(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:03.720449 [ 5978 ] {1001b63b-4672-476e-a438-6fdf75e51abc} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function firstSignificantSubdomain: In scope SELECT firstSignificantSubdomain(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 558, line 559) (in query: SELECT firstSignificantSubdomain(-1);) 2025.06.13 15:44:03.735618 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function firstSignificantSubdomain: In scope SELECT firstSignificantSubdomain(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:03.744069 [ 8431 ] {1b57b172-ebf2-4acb-bf97-a0ffbdddcd6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 0, should be greater or equal to 3: In scope SELECT joinGet(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 770, line 771) (in query: SELECT joinGet();) 2025.06.13 15:44:03.752668 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 0, should be greater or equal to 3: In scope SELECT joinGet(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:03.864012 [ 5978 ] {47c15ee0-f126-4e94-9c51-00d7ea22d90a} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 1, should be 2: In scope SELECT firstSignificantSubdomainCustom(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 559, line 560) (in query: SELECT firstSignificantSubdomainCustom(-1);) 2025.06.13 15:44:03.869228 [ 8431 ] {c1d5c950-022f-4192-b166-55ea55c74415} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 0, should be greater or equal to 3: In scope SELECT joinGetOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 771, line 772) (in query: SELECT joinGetOrNull();) 2025.06.13 15:44:03.871182 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 1, should be 2: In scope SELECT firstSignificantSubdomainCustom(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:03.876454 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 0, should be greater or equal to 3: In scope SELECT joinGetOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:03.959047 [ 5978 ] {1e700cbf-9b57-475d-a1f1-6c084545be0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 1, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 560, line 561) (in query: SELECT firstSignificantSubdomainCustomRFC(-1);) 2025.06.13 15:44:03.966222 [ 8431 ] {08e71687-f7fb-48f7-8118-27f51d9fc60c} executeQuery: Code: 35. DB::Exception: Function JSONMergePatch requires at least one argument.: In scope SELECT jsonMergePatch(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 772, line 773) (in query: SELECT jsonMergePatch();) 2025.06.13 15:44:03.968433 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 1, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:03.973925 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function JSONMergePatch requires at least one argument.: In scope SELECT jsonMergePatch(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:04.047463 [ 5978 ] {4fa1b6cc-46a8-4c15-81bf-47517bfe297c} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function firstSignificantSubdomainRFC: In scope SELECT firstSignificantSubdomainRFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 561, line 562) (in query: SELECT firstSignificantSubdomainRFC(-1);) 2025.06.13 15:44:04.057453 [ 8431 ] {4c650a24-bd07-491e-bd55-bf6738675ea3} executeQuery: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 0, should be 2: In scope SELECT jumpConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 773, line 774) (in query: SELECT jumpConsistentHash();) 2025.06.13 15:44:04.108119 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function firstSignificantSubdomainRFC: In scope SELECT firstSignificantSubdomainRFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:04.129697 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 0, should be 2: In scope SELECT jumpConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:04.314889 [ 6234 ] {0d385cec-6048-4c51-b57c-9fbd5b614217} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56328) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1500001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:04.342996 [ 6234 ] {0d385cec-6048-4c51-b57c-9fbd5b614217} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:04.386378 [ 8431 ] {ad19fe9d-0c21-4d6e-9027-ff2bb445c820} executeQuery: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 0, should be 1: In scope SELECT keccak256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 775, line 776) (in query: SELECT keccak256();) 2025.06.13 15:44:04.391739 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 0, should be 1: In scope SELECT keccak256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:04.454031 [ 8431 ] {f3ccce06-37e3-46f2-b801-27b004f6938e} executeQuery: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 776, line 777) (in query: SELECT kolmogorovSmirnovTest();) 2025.06.13 15:44:04.458704 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:04.540746 [ 8431 ] {409a0519-ffd1-4430-80ca-2bd904b6a2ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 0, should be 2: In scope SELECT kostikConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 777, line 778) (in query: SELECT kostikConsistentHash();) 2025.06.13 15:44:04.551272 [ 5978 ] {0767b473-948c-4656-b9bf-d1d2a368eb69} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Int8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 565, line 566) (in query: SELECT flameGraph(-1);) 2025.06.13 15:44:04.577724 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 0, should be 2: In scope SELECT kostikConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:04.582795 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Int8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:04.670218 [ 5978 ] {4174e5b6-e4a7-420c-b987-60f3a79b7424} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function arrayFlatten, expected Array: In scope SELECT flatten(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 566, line 567) (in query: SELECT flatten(-1);) 2025.06.13 15:44:04.672413 [ 8431 ] {75d36b2a-8672-43ca-b0e0-16da59d5f027} executeQuery: Code: 35. DB::Exception: Function kql_array_sort_asc needs at least one argument; passed 0.: In scope SELECT kql_array_sort_asc(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 778, line 779) (in query: SELECT kql_array_sort_asc();) 2025.06.13 15:44:04.676434 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function arrayFlatten, expected Array: In scope SELECT flatten(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:04.680128 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function kql_array_sort_asc needs at least one argument; passed 0.: In scope SELECT kql_array_sort_asc(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:04.705286 [ 5978 ] {21058a48-976d-470c-be89-6d20b99fc817} executeQuery: Code: 43. DB::Exception: Argument for function 'flattenTuple' must be Named Tuple. Got 'Int8': In scope SELECT flattenTuple(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 567, line 568) (in query: SELECT flattenTuple(-1);) 2025.06.13 15:44:04.708407 [ 8431 ] {d6cb08e5-f10c-4d3d-bd78-a38d8368d264} executeQuery: Code: 35. DB::Exception: Function kql_array_sort_desc needs at least one argument; passed 0.: In scope SELECT kql_array_sort_desc(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 779, line 780) (in query: SELECT kql_array_sort_desc();) 2025.06.13 15:44:04.709906 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function 'flattenTuple' must be Named Tuple. Got 'Int8': In scope SELECT flattenTuple(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:04.713453 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function kql_array_sort_desc needs at least one argument; passed 0.: In scope SELECT kql_array_sort_desc(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:04.777099 [ 8431 ] {d1375b0e-f59b-4445-a1de-ab6e94334b8d} executeQuery: Code: 42. DB::Exception: Aggregate function kurtPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 780, line 781) (in query: SELECT kurtPop();) 2025.06.13 15:44:04.782251 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function kurtPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:04.898534 [ 8431 ] {847fb729-4413-4bd7-9884-f4ce7ac15d79} executeQuery: Code: 42. DB::Exception: Aggregate function kurtSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 781, line 782) (in query: SELECT kurtSamp();) 2025.06.13 15:44:04.902213 [ 5978 ] {fe78f246-33b3-4653-82a7-5ff6f4c3a544} executeQuery: Code: 42. DB::Exception: Number of arguments for function format doesn't match: passed 1, should be at least 2: In scope SELECT format(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 569, line 570) (in query: SELECT format(-1);) 2025.06.13 15:44:04.906333 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function kurtSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:04.911662 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function format doesn't match: passed 1, should be at least 2: In scope SELECT format(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:04.961258 [ 8431 ] {0c774d03-6a8a-489b-b7cb-90e64df12d87} executeQuery: Code: 35. DB::Exception: Function lagInFrame takes at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 782, line 783) (in query: SELECT lagInFrame();) 2025.06.13 15:44:04.963024 [ 5978 ] {4a301888-ff10-490a-990b-49b77926a660} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 1, should be 2 or 3: In scope SELECT formatDateTime(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 570, line 571) (in query: SELECT formatDateTime(-1);) 2025.06.13 15:44:04.978742 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 1, should be 2 or 3: In scope SELECT formatDateTime(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:04.982116 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function lagInFrame takes at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:05.076101 [ 8431 ] {08b45415-44c2-4460-891d-752e27e9495b} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 783, line 784) (in query: SELECT largestTriangleThreeBuckets();) 2025.06.13 15:44:05.084140 [ 5978 ] {60d5861d-478c-4509-9177-4bf188977d70} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTimeInJodaSyntax doesn't match: passed 1, should be 2 or 3: In scope SELECT formatDateTimeInJodaSyntax(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 571, line 572) (in query: SELECT formatDateTimeInJodaSyntax(-1);) 2025.06.13 15:44:05.084579 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:05.090881 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTimeInJodaSyntax doesn't match: passed 1, should be 2 or 3: In scope SELECT formatDateTimeInJodaSyntax(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:05.183479 [ 8431 ] {49876086-c031-45ed-83ef-aee50f284e2c} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 784, line 785) (in query: SELECT lastValueRespectNulls();) 2025.06.13 15:44:05.192003 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:05.193706 [ 5978 ] {32a0463d-7cc9-4e5b-b98a-d002e7814c32} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQuery'. Expected: String, got: Int8: In scope SELECT formatQuery(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 572, line 573) (in query: SELECT formatQuery(-1);) 2025.06.13 15:44:05.206798 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQuery'. Expected: String, got: Int8: In scope SELECT formatQuery(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:05.320388 [ 8431 ] {bf1faa67-0f25-4dd4-86b2-6cc85749d290} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 785, line 786) (in query: SELECT last_value();) 2025.06.13 15:44:05.337414 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:05.348213 [ 5978 ] {adce1167-49f4-4480-98ed-2c5f9b124280} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQueryOrNull'. Expected: String, got: Int8: In scope SELECT formatQueryOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 573, line 574) (in query: SELECT formatQueryOrNull(-1);) 2025.06.13 15:44:05.383242 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQueryOrNull'. Expected: String, got: Int8: In scope SELECT formatQueryOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:05.456737 [ 8431 ] {09076560-b3a3-4dff-b29a-d53d625f8871} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 786, line 787) (in query: SELECT last_value_respect_nulls();) 2025.06.13 15:44:05.465974 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:05.478408 [ 5978 ] {532837fe-0f5e-440d-8eed-857acb89debf} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQuerySingleLine'. Expected: String, got: Int8: In scope SELECT formatQuerySingleLine(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 574, line 575) (in query: SELECT formatQuerySingleLine(-1);) 2025.06.13 15:44:05.485174 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQuerySingleLine'. Expected: String, got: Int8: In scope SELECT formatQuerySingleLine(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:05.581381 [ 8431 ] {d35cc59f-ca72-4747-9527-69318a4274d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 0, should be 1: In scope SELECT lcase(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 787, line 788) (in query: SELECT lcase();) 2025.06.13 15:44:05.589801 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 0, should be 1: In scope SELECT lcase(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:05.612728 [ 5978 ] {5ff031f7-eac5-4ca5-8d69-05e8afa69579} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQuerySingleLineOrNull'. Expected: String, got: Int8: In scope SELECT formatQuerySingleLineOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 575, line 576) (in query: SELECT formatQuerySingleLineOrNull(-1);) 2025.06.13 15:44:05.621421 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'query' to function 'formatQuerySingleLineOrNull'. Expected: String, got: Int8: In scope SELECT formatQuerySingleLineOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:05.685263 [ 4098 ] {f37ede95-3b8f-4454-9fb7-d7ddc22a6e05} 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.20286.altinityantalya (altinity build)) (from [::1]:34044) (comment: 03008_azure_plain_rewritable_with_slash.sh) (query 1, line 2) (in query: CREATE TABLE test_azure_mt (`a` Int32, `b` Int64, `c` Int64) ENGINE = MergeTree PARTITION BY intDiv(a, 1000) ORDER BY (a, b) SETTINGS disk = disk(type = object_storage, metadata_type = plain_rewritable, object_storage_type = azure_blob_storage, name = 'cont-03008-azure-plain-rewritable-with-slash-test-1', path = '/var/lib/clickhouse/disks/cont-03008-azure-plain-rewritable-with-slash-test-1/tables', container_name = 'cont-03008-azure-plain-rewritable-with-slash-test-1', endpoint = 'http://localhost:10000/devstoreaccount1/cont-03008-azure-plain-rewritable-with-slash-test-1/plain-tables/', endpoint_subpath = '6c2391fa62b7', account_name = 'devstoreaccount1', account_key = 'Eby8vdM02xNOcqFlqUwJPLlmEtlCDXJ1OUzFT50uSRZ6IFsuFq2UVErCz4I6tq/K1SZFPTOtr/KBHBeksoGMGw=='), index_granularity = 28005, 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 = 536870912, compact_parts_max_bytes_to_buffer = 268219071, compact_parts_max_granules_to_buffer = 47, compact_parts_merge_max_bytes_to_prefetch_part = 22885514, merge_max_block_size = 17113, old_parts_lifetime = 372., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 783113, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9952267025, index_granularity_bytes = 11089768, 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 = 38425, primary_key_compress_block_size = 33343, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./contrib/llvm-project/libcxx/src/support/runtime/stdexcept_default.ipp:32: std::runtime_error::runtime_error(String const&) @ 0x0000000038faa2de 2. ./build_docker/./contrib/azure/sdk/core/azure-core/src/exception.cpp:20: Azure::Core::RequestFailedException::RequestFailedException(String const&) @ 0x00000000361fc56e 3. ./contrib/azure/sdk/core/azure-core/inc/azure/core/http/http.hpp:66: Azure::Core::Http::CurlConnection::CurlConnection(Azure::Core::Http::Request&, Azure::Core::Http::CurlTransportOptions const&, String const&, String const&) @ 0x00000000361f7ed5 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: Azure::Core::Http::_detail::CurlConnectionPool::ExtractOrCreateCurlConnection(Azure::Core::Http::Request&, Azure::Core::Http::CurlTransportOptions const&, bool) @ 0x00000000361ef015 5. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/curl/curl.cpp:351: Azure::Core::Http::CurlTransport::Send(Azure::Core::Http::Request&, Azure::Core::Context const&) @ 0x00000000361edc8c 6. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/transport_policy.cpp:121: Azure::Core::Http::Policies::_internal::TransportPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003622c810 7. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/log_policy.cpp:114: Azure::Core::Http::Policies::_internal::LogPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003620a3a1 8. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/request_activity_policy.cpp:110: Azure::Core::Http::Policies::_internal::RequestActivityPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003622a622 9. ./contrib/azure/sdk/storage/azure-storage-common/inc/azure/storage/common/internal/shared_key_policy.hpp:36: Azure::Storage::_internal::SharedKeyPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036239348 10. ./build_docker/./contrib/azure/sdk/storage/azure-storage-common/src/storage_per_retry_policy.cpp:57: Azure::Storage::_internal::StoragePerRetryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003628529f 11. ./build_docker/./contrib/azure/sdk/storage/azure-storage-common/src/storage_switch_to_secondary_policy.cpp:36: Azure::Storage::_internal::StorageSwitchToSecondaryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036285735 12. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/retry_policy.cpp:146: Azure::Core::Http::Policies::_internal::RetryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036229018 13. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/telemetry_policy.cpp:23: Azure::Core::Http::Policies::_internal::TelemetryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003622cbe3 14. ./contrib/azure/sdk/core/azure-core/inc/azure/core/http/policies/policy.hpp:453: Azure::Core::Http::Policies::_internal::RequestIdPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003621f89a 15. ./contrib/azure/sdk/storage/azure-storage-common/inc/azure/storage/common/internal/storage_service_version_policy.hpp:34: Azure::Storage::_internal::StorageServiceVersionPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x00000000362396aa 16. ./contrib/azure/sdk/core/azure-core/inc/azure/core/internal/http/pipeline.hpp:230: Azure::Storage::Blobs::_detail::BlobContainerClient::GetProperties(Azure::Core::Http::_internal::HttpPipeline&, Azure::Core::Url const&, Azure::Storage::Blobs::_detail::BlobContainerClient::GetBlobContainerPropertiesOptions const&, Azure::Core::Context const&) @ 0x00000000362563ae 17. ./build_docker/./contrib/azure/sdk/storage/azure-storage-blobs/src/blob_container_client.cpp:324: Azure::Storage::Blobs::BlobContainerClient::GetProperties(Azure::Storage::Blobs::GetBlobContainerPropertiesOptions const&, Azure::Core::Context const&) const @ 0x00000000362412d0 18. ./build_docker/./src/Disks/ObjectStorages/AzureBlobStorage/AzureBlobStorageCommon.cpp:105: DB::AzureBlobStorage::ContainerClientWrapper::GetProperties() const @ 0x000000002b89d715 19. ./build_docker/./src/Disks/ObjectStorages/AzureBlobStorage/AzureBlobStorageCommon.cpp:319: DB::AzureBlobStorage::getContainerClient(DB::AzureBlobStorage::ConnectionParams const&, bool) @ 0x000000002b8a0be9 20. ./build_docker/./src/Disks/ObjectStorages/ObjectStorageFactory.cpp:308: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr const&, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr const&, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr const&, bool) @ 0x000000002ca18988 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ca15714 22. ./build_docker/./src/Disks/ObjectStorages/RegisterDiskObjectStorage.cpp:27: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002ca146b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 24. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 25. ./build_docker/./src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:ne190107], String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x0000000030fd993c 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d4a40b1 27. ./build_docker/./src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000030fd8323 28. ./build_docker/./src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000030fda5fe 29. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000030fda1cd 30. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030fd9188 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000030f97244 2025.06.13 15:44:05.752260 [ 4098 ] {} TCPHandler: Code: 1001. DB::Exception: Azure::Core::Http::TransportException: Fail to get a new connection for: http://localhost:10000. Could not connect to server. (STD_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./contrib/llvm-project/libcxx/src/support/runtime/stdexcept_default.ipp:32: std::runtime_error::runtime_error(String const&) @ 0x0000000038faa2de 2. ./build_docker/./contrib/azure/sdk/core/azure-core/src/exception.cpp:20: Azure::Core::RequestFailedException::RequestFailedException(String const&) @ 0x00000000361fc56e 3. ./contrib/azure/sdk/core/azure-core/inc/azure/core/http/http.hpp:66: Azure::Core::Http::CurlConnection::CurlConnection(Azure::Core::Http::Request&, Azure::Core::Http::CurlTransportOptions const&, String const&, String const&) @ 0x00000000361f7ed5 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: Azure::Core::Http::_detail::CurlConnectionPool::ExtractOrCreateCurlConnection(Azure::Core::Http::Request&, Azure::Core::Http::CurlTransportOptions const&, bool) @ 0x00000000361ef015 5. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/curl/curl.cpp:351: Azure::Core::Http::CurlTransport::Send(Azure::Core::Http::Request&, Azure::Core::Context const&) @ 0x00000000361edc8c 6. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/transport_policy.cpp:121: Azure::Core::Http::Policies::_internal::TransportPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003622c810 7. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/log_policy.cpp:114: Azure::Core::Http::Policies::_internal::LogPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003620a3a1 8. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/request_activity_policy.cpp:110: Azure::Core::Http::Policies::_internal::RequestActivityPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003622a622 9. ./contrib/azure/sdk/storage/azure-storage-common/inc/azure/storage/common/internal/shared_key_policy.hpp:36: Azure::Storage::_internal::SharedKeyPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036239348 10. ./build_docker/./contrib/azure/sdk/storage/azure-storage-common/src/storage_per_retry_policy.cpp:57: Azure::Storage::_internal::StoragePerRetryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003628529f 11. ./build_docker/./contrib/azure/sdk/storage/azure-storage-common/src/storage_switch_to_secondary_policy.cpp:36: Azure::Storage::_internal::StorageSwitchToSecondaryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036285735 12. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/retry_policy.cpp:146: Azure::Core::Http::Policies::_internal::RetryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x0000000036229018 13. ./build_docker/./contrib/azure/sdk/core/azure-core/src/http/telemetry_policy.cpp:23: Azure::Core::Http::Policies::_internal::TelemetryPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003622cbe3 14. ./contrib/azure/sdk/core/azure-core/inc/azure/core/http/policies/policy.hpp:453: Azure::Core::Http::Policies::_internal::RequestIdPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x000000003621f89a 15. ./contrib/azure/sdk/storage/azure-storage-common/inc/azure/storage/common/internal/storage_service_version_policy.hpp:34: Azure::Storage::_internal::StorageServiceVersionPolicy::Send(Azure::Core::Http::Request&, Azure::Core::Http::Policies::NextHttpPolicy, Azure::Core::Context const&) const @ 0x00000000362396aa 16. ./contrib/azure/sdk/core/azure-core/inc/azure/core/internal/http/pipeline.hpp:230: Azure::Storage::Blobs::_detail::BlobContainerClient::GetProperties(Azure::Core::Http::_internal::HttpPipeline&, Azure::Core::Url const&, Azure::Storage::Blobs::_detail::BlobContainerClient::GetBlobContainerPropertiesOptions const&, Azure::Core::Context const&) @ 0x00000000362563ae 17. ./build_docker/./contrib/azure/sdk/storage/azure-storage-blobs/src/blob_container_client.cpp:324: Azure::Storage::Blobs::BlobContainerClient::GetProperties(Azure::Storage::Blobs::GetBlobContainerPropertiesOptions const&, Azure::Core::Context const&) const @ 0x00000000362412d0 18. ./build_docker/./src/Disks/ObjectStorages/AzureBlobStorage/AzureBlobStorageCommon.cpp:105: DB::AzureBlobStorage::ContainerClientWrapper::GetProperties() const @ 0x000000002b89d715 19. ./build_docker/./src/Disks/ObjectStorages/AzureBlobStorage/AzureBlobStorageCommon.cpp:319: DB::AzureBlobStorage::getContainerClient(DB::AzureBlobStorage::ConnectionParams const&, bool) @ 0x000000002b8a0be9 20. ./build_docker/./src/Disks/ObjectStorages/ObjectStorageFactory.cpp:308: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr const&, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr const&, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr const&, bool) @ 0x000000002ca18988 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ca15714 22. ./build_docker/./src/Disks/ObjectStorages/RegisterDiskObjectStorage.cpp:27: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002ca146b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 24. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 25. ./build_docker/./src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:ne190107], String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x0000000030fd993c 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d4a40b1 27. ./build_docker/./src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000030fd8323 28. ./build_docker/./src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000030fda5fe 29. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000030fda1cd 30. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000030fd9188 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000030f97244 2025.06.13 15:44:05.795512 [ 8431 ] {1708e012-e2d9-4c4f-ae4b-c1ac935b0aad} executeQuery: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 0, should be 2: In scope SELECT lcm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 788, line 789) (in query: SELECT lcm();) 2025.06.13 15:44:05.824326 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 0, should be 2: In scope SELECT lcm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:05.900048 [ 8431 ] {9db6085a-9c52-4a23-a405-c101afbc9b89} executeQuery: Code: 35. DB::Exception: Function leadInFrame takes at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 789, line 790) (in query: SELECT leadInFrame();) 2025.06.13 15:44:05.908479 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function leadInFrame takes at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:06.009027 [ 8431 ] {a18edc6c-1605-42c2-8529-d345d91f80e1} executeQuery: Code: 42. DB::Exception: Function least cannot be called without arguments: In scope SELECT least(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 790, line 791) (in query: SELECT least();) 2025.06.13 15:44:06.020001 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function least cannot be called without arguments: In scope SELECT least(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:06.125447 [ 8431 ] {4131696a-943f-48fb-8e13-1aa92d1ce6ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 0, should be 2: In scope SELECT left(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 791, line 792) (in query: SELECT left();) 2025.06.13 15:44:06.140058 [ 6234 ] {faba5672-d69a-4188-8025-d6763e08200a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.86 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56332) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 5000000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:06.144177 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 0, should be 2: In scope SELECT left(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:06.145400 [ 6234 ] {faba5672-d69a-4188-8025-d6763e08200a} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.86 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:06.228613 [ 8431 ] {8c5de065-e0e1-4e5d-88e0-933817fc60ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 0, should be 2 or 3: In scope SELECT leftPad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 792, line 793) (in query: SELECT leftPad();) 2025.06.13 15:44:06.243050 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 0, should be 2 or 3: In scope SELECT leftPad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:06.358301 [ 8431 ] {fac3724a-73c2-4b0b-9000-4b9fee5bffe2} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPadUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT leftPadUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 793, line 794) (in query: SELECT leftPadUTF8();) 2025.06.13 15:44:06.396045 [ 5978 ] {c3faa8d8-5698-4c27-bdf4-d03ecc6b4469} executeQuery: Code: 42. DB::Exception: Function formatRow requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRow(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 580, line 581) (in query: SELECT formatRow(-1);) 2025.06.13 15:44:06.416240 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function formatRow requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRow(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:06.458962 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPadUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT leftPadUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:06.596671 [ 8431 ] {45ea3a13-3f62-446d-a782-076a66251c56} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 0, should be 2: In scope SELECT leftUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 794, line 795) (in query: SELECT leftUTF8();) 2025.06.13 15:44:06.614753 [ 5978 ] {23a56104-3cc6-4dda-8374-2b146a15f629} executeQuery: Code: 42. DB::Exception: Function formatRowNoNewline requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRowNoNewline(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 581, line 582) (in query: SELECT formatRowNoNewline(-1);) 2025.06.13 15:44:06.635044 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 0, should be 2: In scope SELECT leftUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:06.640669 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function formatRowNoNewline requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRowNoNewline(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:06.711877 [ 8431 ] {a8c60801-ca2a-4915-bb8a-95db320dbf08} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 795, line 796) (in query: SELECT lemmatize();) 2025.06.13 15:44:06.713077 [ 5978 ] {8d18e693-57bc-4bec-8a56-e188612e30df} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function fragment: In scope SELECT fragment(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 582, line 583) (in query: SELECT fragment(-1);) 2025.06.13 15:44:06.722972 [ 8431 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:44:06.724727 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function fragment: In scope SELECT fragment(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:06.822820 [ 5978 ] {1340db6f-fc02-4aba-81f2-53c43f641139} executeQuery: Code: 69. DB::Exception: Expected a non-negative integer, got: -1: In scope SELECT fromDaysSinceYearZero(-1). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 583, line 584) (in query: SELECT fromDaysSinceYearZero(-1);) 2025.06.13 15:44:06.829581 [ 8431 ] {e1ab4b07-2a78-4e1c-9537-5422e4493ea3} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 0, should be 1: In scope SELECT length(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 796, line 797) (in query: SELECT length();) 2025.06.13 15:44:06.831362 [ 5978 ] {} TCPHandler: Code: 69. DB::Exception: Expected a non-negative integer, got: -1: In scope SELECT fromDaysSinceYearZero(-1). (ARGUMENT_OUT_OF_BOUND) 2025.06.13 15:44:06.838871 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 0, should be 1: In scope SELECT length(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:06.949254 [ 8431 ] {e3e69e15-ebcf-4b2d-823c-7f822ca1a60b} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT lengthUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 797, line 798) (in query: SELECT lengthUTF8();) 2025.06.13 15:44:06.979094 [ 5978 ] {b0e380e9-de28-4ca6-a903-91525b264565} executeQuery: Code: 69. DB::Exception: Expected a non-negative integer, got: -1: In scope SELECT fromDaysSinceYearZero32(-1). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 584, line 585) (in query: SELECT fromDaysSinceYearZero32(-1);) 2025.06.13 15:44:06.988643 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT lengthUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:07.022578 [ 5978 ] {} TCPHandler: Code: 69. DB::Exception: Expected a non-negative integer, got: -1: In scope SELECT fromDaysSinceYearZero32(-1). (ARGUMENT_OUT_OF_BOUND) 2025.06.13 15:44:07.115946 [ 8431 ] {3d40a48b-2544-48db-8e3b-702e7213522b} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 0, should be 2: In scope SELECT less(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 798, line 799) (in query: SELECT less();) 2025.06.13 15:44:07.122910 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 0, should be 2: In scope SELECT less(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:07.184725 [ 8431 ] {c14225d2-373b-42e4-9eec-0f689869fa2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 0, should be 2: In scope SELECT lessOrEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 799, line 800) (in query: SELECT lessOrEquals();) 2025.06.13 15:44:07.202350 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 0, should be 2: In scope SELECT lessOrEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:07.282724 [ 8431 ] {c49f7d5a-656c-4f5a-b5b3-c1fecc1765d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 0, should be 2: In scope SELECT levenshteinDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 800, line 801) (in query: SELECT levenshteinDistance();) 2025.06.13 15:44:07.293514 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 0, should be 2: In scope SELECT levenshteinDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:07.375165 [ 8431 ] {6450fb80-b9a7-43eb-a977-575dbddef405} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT levenshteinDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 801, line 802) (in query: SELECT levenshteinDistanceUTF8();) 2025.06.13 15:44:07.391873 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT levenshteinDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:07.462152 [ 5978 ] {ad3b1f89-71b6-417c-b8c9-90ce231f263a} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT fromUTCTimestamp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 587, line 588) (in query: SELECT fromUTCTimestamp(-1);) 2025.06.13 15:44:07.478681 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT fromUTCTimestamp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:07.524480 [ 8431 ] {c4630716-4d5f-4acf-a8e0-72687ff55614} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 0, should be 1: In scope SELECT lgamma(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 802, line 803) (in query: SELECT lgamma();) 2025.06.13 15:44:07.550353 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 0, should be 1: In scope SELECT lgamma(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:07.667828 [ 8431 ] {fc08ea89-a937-4d00-9d54-2d40b273a2b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 0, should be 2: In scope SELECT like(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 803, line 804) (in query: SELECT like();) 2025.06.13 15:44:07.695078 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 0, should be 2: In scope SELECT like(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:07.762763 [ 8431 ] {4b1a9c21-a5a6-4fbd-8561-b73863ac3d44} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 0, should be 1: In scope SELECT ln(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 804, line 805) (in query: SELECT ln();) 2025.06.13 15:44:07.801407 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 0, should be 1: In scope SELECT ln(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:07.929783 [ 6234 ] {74039075-c053-440e-bbfa-8fe0348a7240} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.86 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56346) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 5000000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:07.935144 [ 8431 ] {c3551a63-e148-497c-a132-97062ff90e44} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 805, line 806) (in query: SELECT locate();) 2025.06.13 15:44:07.936022 [ 6234 ] {74039075-c053-440e-bbfa-8fe0348a7240} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.86 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:07.944238 [ 8431 ] {} 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) 2025.06.13 15:44:07.969171 [ 8442 ] {1529c0a0-17fc-4885-abc3-7f076c4c9c95} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 2, should be 1: In scope SELECT toStringCutToZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1455, line 1457) (in query: SELECT toStringCutToZero(NULL, NULL);) 2025.06.13 15:44:07.976775 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 2, should be 1: In scope SELECT toStringCutToZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:08.019871 [ 8431 ] {6b719dc1-f3ce-48af-ad7b-f6c63b4a9a7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 0, should be 1: In scope SELECT log(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 806, line 807) (in query: SELECT log();) 2025.06.13 15:44:08.030698 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 0, should be 1: In scope SELECT log(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:08.134515 [ 8431 ] {ce165154-88af-4ac8-9cbf-383f1c7d83ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 0, should be 1: In scope SELECT log10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 807, line 808) (in query: SELECT log10();) 2025.06.13 15:44:08.148594 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 0, should be 1: In scope SELECT log10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:08.264083 [ 8431 ] {f49bfe87-a581-4f6b-be26-66c27632668a} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 0, should be 1: In scope SELECT log1p(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 808, line 809) (in query: SELECT log1p();) 2025.06.13 15:44:08.291768 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 0, should be 1: In scope SELECT log1p(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:08.429355 [ 8431 ] {45cfdc75-0222-4889-8117-7513065eaa36} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 0, should be 1: In scope SELECT log2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 809, line 810) (in query: SELECT log2();) 2025.06.13 15:44:08.448340 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 0, should be 1: In scope SELECT log2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:08.544040 [ 5978 ] {ec2a367d-2f6d-44c5-b1a4-7756022ced3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT from_utc_timestamp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 594, line 595) (in query: SELECT from_utc_timestamp(-1);) 2025.06.13 15:44:08.564392 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT from_utc_timestamp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:08.594574 [ 8431 ] {2008b1d3-6301-48dc-b871-17d32e82e454} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 0, should be 1: In scope SELECT logTrace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 810, line 811) (in query: SELECT logTrace();) 2025.06.13 15:44:08.633110 [ 8442 ] {42a9ba40-f232-42ec-873b-781b2d035f7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 2, should be 1: In scope SELECT toTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1459, line 1461) (in query: SELECT toTypeName(NULL, NULL);) 2025.06.13 15:44:08.633631 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 0, should be 1: In scope SELECT logTrace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:08.642341 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 2, should be 1: In scope SELECT toTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:08.733771 [ 5978 ] {e6f9d87f-da40-4a92-a08a-364232c76a2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 1, should be 0: In scope SELECT fullHostName(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 595, line 596) (in query: SELECT fullHostName(-1);) 2025.06.13 15:44:08.743946 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 1, should be 0: In scope SELECT fullHostName(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:08.752881 [ 8431 ] {bef2fee3-bb1d-4579-8a64-4dbee19a06e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 0, should be 1: In scope SELECT lowCardinalityIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 811, line 812) (in query: SELECT lowCardinalityIndices();) 2025.06.13 15:44:08.766772 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 0, should be 1: In scope SELECT lowCardinalityIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:08.802919 [ 5978 ] {99609e4d-842f-47cf-be4b-cf2465cab004} executeQuery: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 1, should be 2: In scope SELECT fuzzBits(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 596, line 597) (in query: SELECT fuzzBits(-1);) 2025.06.13 15:44:08.810951 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 1, should be 2: In scope SELECT fuzzBits(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:08.880537 [ 8431 ] {6bce7d6f-18a3-4385-b7db-cbfeda4e1d46} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 0, should be 1: In scope SELECT lowCardinalityKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 812, line 813) (in query: SELECT lowCardinalityKeys();) 2025.06.13 15:44:08.890292 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 0, should be 1: In scope SELECT lowCardinalityKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:08.976901 [ 8431 ] {723f7bd7-1a92-4a9e-a5d2-35ab720a5b0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 0, should be 1: In scope SELECT lower(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 813, line 814) (in query: SELECT lower();) 2025.06.13 15:44:08.982811 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 0, should be 1: In scope SELECT lower(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:09.005964 [ 8442 ] {c2740760-ca33-4c44-ae80-34c7e8d66994} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt128. Actual Nullable(Nothing): In scope SELECT toUInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1461, line 1463) (in query: SELECT toUInt128OrDefault(NULL, NULL);) 2025.06.13 15:44:09.087873 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt128. Actual Nullable(Nothing): In scope SELECT toUInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:44:09.101783 [ 5978 ] {adcb75ea-03d4-47c0-9e50-cbc3e180b6f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 1, should be 2: In scope SELECT gcd(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 598, line 599) (in query: SELECT gcd(-1);) 2025.06.13 15:44:09.108937 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 1, should be 2: In scope SELECT gcd(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:09.174957 [ 8431 ] {fa97f5e5-8422-4edd-8771-46187b068104} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 0, should be 1: In scope SELECT lowerUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 814, line 815) (in query: SELECT lowerUTF8();) 2025.06.13 15:44:09.180274 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 0, should be 1: In scope SELECT lowerUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:09.204064 [ 5978 ] {3cf32bd7-0449-4eb2-bce9-39fa5fe57e97} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of the 1 argument of function generateRandomStructure, expected unsigned integer or Null: In scope SELECT generateRandomStructure(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 599, line 600) (in query: SELECT generateRandomStructure(-1);) 2025.06.13 15:44:09.213841 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of the 1 argument of function generateRandomStructure, expected unsigned integer or Null: In scope SELECT generateRandomStructure(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:09.257691 [ 8431 ] {71468a72-1a60-45a1-8ee8-87805ec75a7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 0, should be 2 or 3: In scope SELECT lpad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 815, line 816) (in query: SELECT lpad();) 2025.06.13 15:44:09.276633 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 0, should be 2 or 3: In scope SELECT lpad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:09.282361 [ 18377 ] {95820899-a165-409a-8d0a-2b945bfeb9bc} executeQuery: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33024) (comment: 01621_bar_nan_arguments.sql) (query 1, line 1) (in query: SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f40c75 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:44:09.287998 [ 18377 ] {} TCPHandler: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f40c75 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:44:09.349847 [ 5978 ] {9ec5c7f8-e844-4ebb-b855-c25719ae26a4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: Int8: In scope SELECT generateSerialID(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 600, line 601) (in query: SELECT generateSerialID(-1);) 2025.06.13 15:44:09.362737 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: Int8: In scope SELECT generateSerialID(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:09.382221 [ 8431 ] {229c9b7f-abc7-46e8-a56f-d2e382b790ef} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 816, line 818) (in query: SELECT lttb();) 2025.06.13 15:44:09.417255 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:09.445856 [ 18377 ] {6042d21a-9e48-4560-b9d4-4b48d1b18d30} executeQuery: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar(1, 1, 1, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33024) (comment: 01621_bar_nan_arguments.sql) (query 2, line 2) (in query: select bar(1,1,1,nan);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f40c75 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:44:09.477846 [ 18377 ] {} TCPHandler: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar(1, 1, 1, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f40c75 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:44:09.536022 [ 8431 ] {8fcbcd23-0c49-4903-9e58-622375f9bb38} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 0 arguments: In scope SELECT makeDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 817, line 819) (in query: SELECT makeDate();) 2025.06.13 15:44:09.556945 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 0 arguments: In scope SELECT makeDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:09.754847 [ 8431 ] {f8d79730-d86d-4a6f-bd82-d9815830a24b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 0 arguments: In scope SELECT makeDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 818, line 820) (in query: SELECT makeDate32();) 2025.06.13 15:44:09.770196 [ 8442 ] {6af8d0d8-aac0-48b1-9eaf-b4b059c5d370} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt16. Actual Nullable(Nothing): In scope SELECT toUInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1465, line 1467) (in query: SELECT toUInt16OrDefault(NULL, NULL);) 2025.06.13 15:44:09.776992 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 0 arguments: In scope SELECT makeDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:09.808294 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt16. Actual Nullable(Nothing): In scope SELECT toUInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:44:09.818055 [ 6234 ] {6a9eb50b-1012-4f82-bb42-ccc8a31335a5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.86 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56362) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 5000000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:09.837340 [ 6234 ] {6a9eb50b-1012-4f82-bb42-ccc8a31335a5} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.86 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:09.932342 [ 8431 ] {530cbacd-872b-433f-92d7-842542e22c73} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT makeDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 819, line 821) (in query: SELECT makeDateTime();) 2025.06.13 15:44:09.996857 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT makeDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:10.057202 [ 8431 ] {61dca3f1-ac78-4a2d-a311-ad2ca938e516} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 0 arguments: In scope SELECT makeDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 820, line 822) (in query: SELECT makeDateTime64();) 2025.06.13 15:44:10.096647 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 0 arguments: In scope SELECT makeDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:10.231110 [ 8431 ] {dcaf0a41-ab93-43d7-b832-848183cc7d9e} executeQuery: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 821, line 823) (in query: SELECT mannWhitneyUTest();) 2025.06.13 15:44:10.236486 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:10.348760 [ 5978 ] {4882fbc3-81c9-4faf-b9e6-9ea995c60b2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 1, should be 4: In scope SELECT geoDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 605, line 606) (in query: SELECT geoDistance(-1);) 2025.06.13 15:44:10.366477 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 1, should be 4: In scope SELECT geoDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:10.492256 [ 5978 ] {43051669-3268-4860-9c40-0905d7dc61f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 1, should be 3: In scope SELECT geoToH3(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 606, line 607) (in query: SELECT geoToH3(-1);) 2025.06.13 15:44:10.498336 [ 8431 ] {590b3de0-58e4-4e5f-b6a4-b2cd14f6db56} executeQuery: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 823, line 825) (in query: SELECT mapAdd();) 2025.06.13 15:44:10.498980 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 1, should be 3: In scope SELECT geoToH3(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:10.509221 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:10.554538 [ 8442 ] {4a4657ca-eca0-4409-b21e-d926cd06ba94} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt256. Actual Nullable(Nothing): In scope SELECT toUInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1469, line 1471) (in query: SELECT toUInt256OrDefault(NULL, NULL);) 2025.06.13 15:44:10.585828 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt256. Actual Nullable(Nothing): In scope SELECT toUInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:44:10.601526 [ 8431 ] {d707bc41-a65a-487b-be9c-0d9babde615e} executeQuery: Code: 42. DB::Exception: Function mapAll requires at least one argument, passed 0: In scope SELECT mapAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 824, line 826) (in query: SELECT mapAll();) 2025.06.13 15:44:10.618681 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function mapAll requires at least one argument, passed 0: In scope SELECT mapAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:10.639277 [ 5978 ] {79749a64-4239-4e7b-ad52-9788df36b3e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 1, should be 2: In scope SELECT geoToS2(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 607, line 608) (in query: SELECT geoToS2(-1);) 2025.06.13 15:44:10.647567 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 1, should be 2: In scope SELECT geoToS2(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:10.721697 [ 8431 ] {57f2d44d-0cc4-48a5-8a58-9f71d938b0b5} executeQuery: Code: 42. DB::Exception: Function mapApply requires at least one argument, passed 0: In scope SELECT mapApply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 825, line 827) (in query: SELECT mapApply();) 2025.06.13 15:44:10.735132 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function mapApply requires at least one argument, passed 0: In scope SELECT mapApply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:10.779726 [ 5978 ] {cb4614b6-8392-4a14-b0ce-6d31c3167e8a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'encoded' to function 'geohashDecode'. Expected: String or FixedString, got: Int8: In scope SELECT geohashDecode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 608, line 609) (in query: SELECT geohashDecode(-1);) 2025.06.13 15:44:10.805501 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'encoded' to function 'geohashDecode'. Expected: String or FixedString, got: Int8: In scope SELECT geohashDecode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:10.861610 [ 8431 ] {a7b2e829-b9c6-4afb-b437-64fe86095f70} executeQuery: Code: 42. DB::Exception: Function mapConcat requires at least one argument, passed 0: In scope SELECT mapConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 826, line 828) (in query: SELECT mapConcat();) 2025.06.13 15:44:10.877569 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function mapConcat requires at least one argument, passed 0: In scope SELECT mapConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:10.964382 [ 5978 ] {60d6cd54-0893-4307-b187-662cb065e8c8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'geohashEncode'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT geohashEncode(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 609, line 610) (in query: SELECT geohashEncode(-1);) 2025.06.13 15:44:10.971992 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'geohashEncode'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT geohashEncode(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:10.973096 [ 8431 ] {272855d5-abdc-4ebc-b672-ec84e0902586} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 0, should be 2: In scope SELECT mapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 827, line 829) (in query: SELECT mapContains();) 2025.06.13 15:44:10.981847 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 0, should be 2: In scope SELECT mapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:11.076538 [ 6234 ] {e60a07ed-b472-4ecc-b3ba-61aad8103ac4} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33074) (comment: 02943_order_by_all.sql) (query 5, line 16) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:11.098577 [ 8431 ] {364202e0-baa9-436f-be74-30c5f365abc6} executeQuery: Code: 42. DB::Exception: Function mapContainsKeyLike requires at least one argument, passed 0: In scope SELECT mapContainsKeyLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 828, line 830) (in query: SELECT mapContainsKeyLike();) 2025.06.13 15:44:11.127768 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function mapContainsKeyLike requires at least one argument, passed 0: In scope SELECT mapContainsKeyLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:11.143199 [ 6234 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:11.164502 [ 5978 ] {6cf68046-5789-4f99-b5eb-0535671328fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 1, should be 5: In scope SELECT geohashesInBox(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 610, line 611) (in query: SELECT geohashesInBox(-1);) 2025.06.13 15:44:11.176649 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 1, should be 5: In scope SELECT geohashesInBox(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:11.179422 [ 3895 ] {38bbb49c-c8e5-4e3a-97b1-3533be283c53::all_1_2_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:11.191063 [ 3895 ] {f3d99e34-ece5-41fc-94a4-cb22b5dced7f} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33092) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:11.201152 [ 3895 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:11.239211 [ 8431 ] {97aa668e-b42f-446f-956f-65ce2042f007} executeQuery: Code: 42. DB::Exception: Function mapExists requires at least one argument, passed 0: In scope SELECT mapExists(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 829, line 831) (in query: SELECT mapExists();) 2025.06.13 15:44:11.266488 [ 8442 ] {845d6784-acd9-46b7-8d46-3be4eda60e81} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt32. Actual Nullable(Nothing): In scope SELECT toUInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1473, line 1475) (in query: SELECT toUInt32OrDefault(NULL, NULL);) 2025.06.13 15:44:11.268071 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function mapExists requires at least one argument, passed 0: In scope SELECT mapExists(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:11.280905 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt32. Actual Nullable(Nothing): In scope SELECT toUInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:44:11.284032 [ 5978 ] {1feeab78-6afc-4c3b-b3ef-6c38e6d51771} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 611, line 612) (in query: SELECT getClientHTTPHeader(-1);) 2025.06.13 15:44:11.304026 [ 5978 ] {} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.06.13 15:44:11.394712 [ 8431 ] {4e08684e-6b83-404d-b346-84d5023769c7} executeQuery: Code: 42. DB::Exception: Function mapExtractKeyLike requires at least one argument, passed 0: In scope SELECT mapExtractKeyLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 830, line 832) (in query: SELECT mapExtractKeyLike();) 2025.06.13 15:44:11.437356 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function mapExtractKeyLike requires at least one argument, passed 0: In scope SELECT mapExtractKeyLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:11.439434 [ 5978 ] {c6dd82c0-3866-4be0-9818-3bd55fb1d5b1} executeQuery: Code: 43. DB::Exception: The argument of function getMacro must have String type: In scope SELECT getMacro(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 612, line 613) (in query: SELECT getMacro(-1);) 2025.06.13 15:44:11.460370 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The argument of function getMacro must have String type: In scope SELECT getMacro(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:11.543964 [ 8431 ] {98b95b88-0aa9-40f9-b66e-17e462dea7b3} executeQuery: Code: 42. DB::Exception: Function mapFilter requires at least one argument, passed 0: In scope SELECT mapFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 831, line 833) (in query: SELECT mapFilter();) 2025.06.13 15:44:11.557977 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function mapFilter requires at least one argument, passed 0: In scope SELECT mapFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:11.610716 [ 5978 ] {57bf6625-4172-4af9-af15-0c8562c54e51} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function getMaxTableNameLengthForDatabase, expected String or FixedString: In scope SELECT getMaxTableNameLengthForDatabase(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 613, line 614) (in query: SELECT getMaxTableNameLengthForDatabase(-1);) 2025.06.13 15:44:11.625605 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function getMaxTableNameLengthForDatabase, expected String or FixedString: In scope SELECT getMaxTableNameLengthForDatabase(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:11.677284 [ 8431 ] {18af80ab-0a4d-4931-9423-d533299cc997} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 0, should be 2: In scope SELECT mapFromArrays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 832, line 834) (in query: SELECT mapFromArrays();) 2025.06.13 15:44:11.686069 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 0, should be 2: In scope SELECT mapFromArrays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:11.737453 [ 5978 ] {46edc296-8b4e-4344-9e32-323071113a20} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 1, should be 0: In scope SELECT getOSKernelVersion(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 614, line 615) (in query: SELECT getOSKernelVersion(-1);) 2025.06.13 15:44:11.744637 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 1, should be 0: In scope SELECT getOSKernelVersion(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:11.854414 [ 8431 ] {3ff4bee2-93e5-41dc-a4b2-ce6d224ad93f} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT mapFromString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 833, line 835) (in query: SELECT mapFromString();) 2025.06.13 15:44:11.861127 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT mapFromString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:11.916013 [ 5978 ] {763cd272-ee78-4663-af8c-083d84a105f7} executeQuery: Code: 43. DB::Exception: The argument of function getServerPort should be a constant string with the name of a setting: In scope SELECT getServerPort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 615, line 616) (in query: SELECT getServerPort(-1);) 2025.06.13 15:44:11.941719 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The argument of function getServerPort should be a constant string with the name of a setting: In scope SELECT getServerPort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:11.960359 [ 8431 ] {da3a3663-f5df-4cd3-8d63-523b62cc8a19} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 0, should be 1: In scope SELECT mapKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 834, line 836) (in query: SELECT mapKeys();) 2025.06.13 15:44:11.965784 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 0, should be 1: In scope SELECT mapKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:12.039310 [ 5978 ] {ffa7cdc9-9eeb-41a6-ae86-681c9aae62bb} executeQuery: Code: 43. DB::Exception: The argument of function getSetting should be a constant string with the name of a setting: In scope SELECT getSetting(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 616, line 617) (in query: SELECT getSetting(-1);) 2025.06.13 15:44:12.048593 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The argument of function getSetting should be a constant string with the name of a setting: In scope SELECT getSetting(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:12.049049 [ 8442 ] {c9a06f5a-cbe1-4401-b521-0fdf5fff5cf2} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt64. Actual Nullable(Nothing): In scope SELECT toUInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1477, line 1479) (in query: SELECT toUInt64OrDefault(NULL, NULL);) 2025.06.13 15:44:12.049251 [ 8431 ] {61db05fc-9ebd-435e-a0e4-d2aba53a8df6} executeQuery: Code: 42. DB::Exception: Function mapPartialReverseSort requires at least one argument, passed 0: In scope SELECT mapPartialReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 835, line 837) (in query: SELECT mapPartialReverseSort();) 2025.06.13 15:44:12.055617 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt64. Actual Nullable(Nothing): In scope SELECT toUInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:44:12.056543 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function mapPartialReverseSort requires at least one argument, passed 0: In scope SELECT mapPartialReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:12.129299 [ 18602 ] {a0222796-cc05-41f7-9249-95903c8f583e} 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.20286.altinityantalya (altinity build)) (from [::1]:33108) (comment: 02374_analyzer_join_using.gen.sql) (query 5, line 11) (in query: CREATE TABLE test_table_join_2 (`id` UInt16, `value` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 46949, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.6985684633255005, replace_long_file_name_to_hash = true, max_file_name_length = 44, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 14902514, compact_parts_max_granules_to_buffer = 103, compact_parts_merge_max_bytes_to_prefetch_part = 26641982, merge_max_block_size = 23489, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1391791599, vertical_merge_algorithm_min_rows_to_activate = 777926, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5793943, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 62, 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 = 10444, primary_key_compress_block_size = 98255, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c90b7a 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c5245 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.141522 [ 5978 ] {ca825d26-9610-48ae-9808-710dc5e0a3f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 1, should be 2: In scope SELECT getSettingOrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 617, line 618) (in query: SELECT getSettingOrDefault(-1);) 2025.06.13 15:44:12.157078 [ 18602 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c90b7a 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c5245 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.173995 [ 3895 ] {307ea683-af62-454f-989e-4b72405aabe8} executeQuery: Code: 36. DB::Exception: The size of bloom filter cannot be zero. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33120) (comment: 01384_bloom_filter_bad_arguments.sql) (query 2, line 3) (in query: CREATE TABLE test (`a` String, INDEX a a TYPE tokenbf_v1(0, 2, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 47927, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.918639600276947, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 216989707, compact_parts_max_bytes_to_buffer = 272576184, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 27423040, merge_max_block_size = 24504, old_parts_lifetime = 165., prefer_fetch_merged_part_size_threshold = 2095659496, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 12812015, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 57, 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 = 73932, primary_key_compress_block_size = 22588, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/BloomFilter.cpp:28: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x000000002dc3accb 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:819: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000030ea57e6 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7a7e7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.176251 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 1, should be 2: In scope SELECT getSettingOrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:12.190864 [ 8431 ] {d471bf02-ff1f-43e8-aa63-6d54c59b63cd} executeQuery: Code: 42. DB::Exception: Function mapPartialSort requires at least one argument, passed 0: In scope SELECT mapPartialSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 836, line 838) (in query: SELECT mapPartialSort();) 2025.06.13 15:44:12.193695 [ 3895 ] {} TCPHandler: Code: 36. DB::Exception: The size of bloom filter cannot be zero. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/BloomFilter.cpp:28: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x000000002dc3accb 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:819: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000030ea57e6 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7a7e7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.210756 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function mapPartialSort requires at least one argument, passed 0: In scope SELECT mapPartialSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:12.329171 [ 5978 ] {1fc8ab62-3d04-4707-9266-8d43f7a130fa} executeQuery: Code: 43. DB::Exception: The argument for function getSizeOfEnumType must be Enum: In scope SELECT getSizeOfEnumType(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 618, line 619) (in query: SELECT getSizeOfEnumType(-1);) 2025.06.13 15:44:12.343044 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The argument for function getSizeOfEnumType must be Enum: In scope SELECT getSizeOfEnumType(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:12.397739 [ 8431 ] {73382439-793b-4f82-9f56-efa6bbefa15e} executeQuery: Code: 42. DB::Exception: Function mapPopulateSeries accepts at least one map or two arrays arguments, and optional max key argument: In scope SELECT mapPopulateSeries(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 837, line 839) (in query: SELECT mapPopulateSeries();) 2025.06.13 15:44:12.402512 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function mapPopulateSeries accepts at least one map or two arrays arguments, and optional max key argument: In scope SELECT mapPopulateSeries(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:12.444985 [ 5978 ] {f2f6aade-42c9-4148-8d95-9900d2ff62a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 1, should be 2: In scope SELECT getSubcolumn(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 619, line 620) (in query: SELECT getSubcolumn(-1);) 2025.06.13 15:44:12.453206 [ 3895 ] {7ffc0898-5da7-4f53-99c6-8077fcd24e44} executeQuery: Code: 36. DB::Exception: The number of hash functions for bloom filter cannot be zero. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33120) (comment: 01384_bloom_filter_bad_arguments.sql) (query 3, line 4) (in query: CREATE TABLE test (`a` String, INDEX a a TYPE tokenbf_v1(2, 0, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 47927, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.918639600276947, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 216989707, compact_parts_max_bytes_to_buffer = 272576184, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 27423040, merge_max_block_size = 24504, old_parts_lifetime = 165., prefer_fetch_merged_part_size_threshold = 2095659496, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 12812015, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 57, 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 = 73932, primary_key_compress_block_size = 22588, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/BloomFilter.cpp:30: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x000000002dc3ad36 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:819: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000030ea57e6 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7a7e7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.462042 [ 8431 ] {3f3cb1a6-4ef6-4acb-8d96-b0234c7e97eb} executeQuery: Code: 42. DB::Exception: Function mapReverseSort requires at least one argument, passed 0: In scope SELECT mapReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 838, line 840) (in query: SELECT mapReverseSort();) 2025.06.13 15:44:12.463652 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 1, should be 2: In scope SELECT getSubcolumn(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:12.470259 [ 3895 ] {} TCPHandler: Code: 36. DB::Exception: The number of hash functions for bloom filter cannot be zero. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/BloomFilter.cpp:30: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x000000002dc3ad36 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:819: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000030ea57e6 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7a7e7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.471901 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function mapReverseSort requires at least one argument, passed 0: In scope SELECT mapReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:12.597279 [ 3895 ] {28423715-8987-4554-bd56-6272080f966f} executeQuery: Code: 36. DB::Exception: The size of bloom filter cannot be zero. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33120) (comment: 01384_bloom_filter_bad_arguments.sql) (query 4, line 5) (in query: CREATE TABLE test (`a` String, INDEX a a TYPE tokenbf_v1(0, 1, 1) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 47927, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.918639600276947, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 216989707, compact_parts_max_bytes_to_buffer = 272576184, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 27423040, merge_max_block_size = 24504, old_parts_lifetime = 165., prefer_fetch_merged_part_size_threshold = 2095659496, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 12812015, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 57, 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 = 73932, primary_key_compress_block_size = 22588, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/BloomFilter.cpp:28: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x000000002dc3accb 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:819: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000030ea57e6 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7a7e7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.600557 [ 8431 ] {a9bb3297-43c1-4810-b4f3-62fffcdcb3a1} executeQuery: Code: 42. DB::Exception: Function mapSort requires at least one argument, passed 0: In scope SELECT mapSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 839, line 841) (in query: SELECT mapSort();) 2025.06.13 15:44:12.607207 [ 3895 ] {} TCPHandler: Code: 36. DB::Exception: The size of bloom filter cannot be zero. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/BloomFilter.cpp:28: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x000000002dc3accb 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:819: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000030ea57e6 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7a7e7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.611440 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function mapSort requires at least one argument, passed 0: In scope SELECT mapSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:12.672270 [ 18377 ] {cc5fce63-798e-44e5-b714-6dc7cbc4fed4} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_nkpekc8y.keeper_retries_r1 (fc10f32a-6845-4cb3-98aa-7c8b52a73b53)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33062) (comment: 02456_keeper_retries_during_insert.sql) (query 5, line 9) (in query: INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_probability=0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.692366 [ 18377 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_nkpekc8y.keeper_retries_r1 (fc10f32a-6845-4cb3-98aa-7c8b52a73b53)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.733013 [ 8431 ] {9e2d502e-169a-4613-beb4-0f7a65a0e329} executeQuery: Code: 42. DB::Exception: mapSubtract accepts at least two maps or map tuples: In scope SELECT mapSubtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 840, line 842) (in query: SELECT mapSubtract();) 2025.06.13 15:44:12.735171 [ 5978 ] {d9468849-fb42-4da4-af2b-26ed7a33cc08} executeQuery: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 621, line 622) (in query: SELECT globalIn(-1);) 2025.06.13 15:44:12.742892 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: mapSubtract accepts at least two maps or map tuples: In scope SELECT mapSubtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:12.743193 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:12.784591 [ 8442 ] {8b9a529d-396c-4a88-b213-f4b556fdc051} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt8. Actual Nullable(Nothing): In scope SELECT toUInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1481, line 1483) (in query: SELECT toUInt8OrDefault(NULL, NULL);) 2025.06.13 15:44:12.797496 [ 3895 ] {0d528f19-a67f-4a90-854c-07ab5aae45d1} executeQuery: Code: 36. DB::Exception: The number of hash functions for bloom filter cannot be zero. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33120) (comment: 01384_bloom_filter_bad_arguments.sql) (query 5, line 6) (in query: CREATE TABLE test (`a` String, INDEX a a TYPE tokenbf_v1(1, 0, 1) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 47927, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.918639600276947, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 216989707, compact_parts_max_bytes_to_buffer = 272576184, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 27423040, merge_max_block_size = 24504, old_parts_lifetime = 165., prefer_fetch_merged_part_size_threshold = 2095659496, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 12812015, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 57, 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 = 73932, primary_key_compress_block_size = 22588, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/BloomFilter.cpp:30: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x000000002dc3ad36 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:819: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000030ea57e6 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7a7e7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.803604 [ 5978 ] {9d49f8ab-372d-4ac0-ad33-86a4987b07cc} executeQuery: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 622, line 623) (in query: SELECT globalInIgnoreSet(-1);) 2025.06.13 15:44:12.804557 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt8. Actual Nullable(Nothing): In scope SELECT toUInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:44:12.807370 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:12.815883 [ 3895 ] {} TCPHandler: Code: 36. DB::Exception: The number of hash functions for bloom filter cannot be zero. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/BloomFilter.cpp:30: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x000000002dc3ad36 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:819: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000030ea57e6 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7a7e7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.816162 [ 8431 ] {83bcb212-9c1a-47c3-a76c-ee6f468ffbce} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 0, should be 2: In scope SELECT mapUpdate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 841, line 843) (in query: SELECT mapUpdate();) 2025.06.13 15:44:12.845661 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 0, should be 2: In scope SELECT mapUpdate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:12.853159 [ 6234 ] {649b50df-74f7-45b3-a92b-eadff25f4f21} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_nkpekc8y.keeper_retries_r1 (fc10f32a-6845-4cb3-98aa-7c8b52a73b53)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34148) (comment: 02456_keeper_retries_during_insert.sql) (in query: DROP DATABASE IF EXISTS test_nkpekc8y SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.855423 [ 6234 ] {649b50df-74f7-45b3-a92b-eadff25f4f21} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_nkpekc8y.keeper_retries_r1 (fc10f32a-6845-4cb3-98aa-7c8b52a73b53)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:12.886466 [ 5978 ] {33df15bb-de0c-40a6-bb61-f5ac0f9b53ea} executeQuery: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 623, line 624) (in query: SELECT globalNotIn(-1);) 2025.06.13 15:44:12.892616 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:12.987541 [ 3895 ] {a58de38d-7808-495d-a1ed-256415b92757} executeQuery: Code: 36. DB::Exception: All parameters to *bf_v1 index must be unsigned integers. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33120) (comment: 01384_bloom_filter_bad_arguments.sql) (query 6, line 8) (in query: CREATE TABLE test (`a` String, INDEX a a TYPE tokenbf_v1(0.1, 2, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 47927, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.918639600276947, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 216989707, compact_parts_max_bytes_to_buffer = 272576184, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 27423040, merge_max_block_size = 24504, old_parts_lifetime = 165., prefer_fetch_merged_part_size_threshold = 2095659496, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 12812015, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 57, 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 = 73932, primary_key_compress_block_size = 22588, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:816: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000030ea5941 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7a7e7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.988339 [ 5978 ] {fd504b8f-d6e4-47b2-8dc7-bea10a877148} executeQuery: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 624, line 625) (in query: SELECT globalNotInIgnoreSet(-1);) 2025.06.13 15:44:12.993327 [ 3895 ] {} TCPHandler: Code: 36. DB::Exception: All parameters to *bf_v1 index must be unsigned integers. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:816: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000030ea5941 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7a7e7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:44:12.993825 [ 8431 ] {2c157c53-eb4b-4da9-811c-a648e3363399} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 0, should be 1: In scope SELECT mapValues(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 842, line 844) (in query: SELECT mapValues();) 2025.06.13 15:44:12.999328 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.002559 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 0, should be 1: In scope SELECT mapValues(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.072273 [ 8431 ] {e0199ea8-850f-4b1c-acbd-203119be0b9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 0, should be 2: In scope SELECT match(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 843, line 845) (in query: SELECT match();) 2025.06.13 15:44:13.083025 [ 5978 ] {1c8f5ea7-7cc4-48c2-909a-a3ada6679b3e} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 625, line 626) (in query: SELECT globalNotNullIn(-1);) 2025.06.13 15:44:13.088087 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.091191 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 0, should be 2: In scope SELECT match(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.143299 [ 3895 ] {e483917f-47d9-4eaf-b9e3-b96e34f0d573} executeQuery: Code: 36. DB::Exception: All parameters to *bf_v1 index must be unsigned integers. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33120) (comment: 01384_bloom_filter_bad_arguments.sql) (query 7, line 9) (in query: CREATE TABLE test (`a` String, INDEX a a TYPE tokenbf_v1(-1, 2, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 47927, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.918639600276947, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 216989707, compact_parts_max_bytes_to_buffer = 272576184, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 27423040, merge_max_block_size = 24504, old_parts_lifetime = 165., prefer_fetch_merged_part_size_threshold = 2095659496, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 12812015, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 57, 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 = 73932, primary_key_compress_block_size = 22588, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:816: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000030ea5941 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7a7e7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:44:13.168126 [ 3895 ] {} TCPHandler: Code: 36. DB::Exception: All parameters to *bf_v1 index must be unsigned integers. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:816: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000030ea5941 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7a7e7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:44:13.188606 [ 5978 ] {0ffdd460-9460-441e-adba-17a048f2f338} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 626, line 627) (in query: SELECT globalNotNullInIgnoreSet(-1);) 2025.06.13 15:44:13.204088 [ 8431 ] {ca2685f8-8bcb-4927-ac89-7b63463d7169} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 0, should be 1: In scope SELECT materialize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 844, line 846) (in query: SELECT materialize();) 2025.06.13 15:44:13.212239 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.216877 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 0, should be 1: In scope SELECT materialize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.309010 [ 5978 ] {8546c83b-d2ed-44d0-b25e-61e77ebae560} executeQuery: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 627, line 628) (in query: SELECT globalNullIn(-1);) 2025.06.13 15:44:13.319285 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.338379 [ 8431 ] {e9fb07f0-e9f7-4a5f-ba40-68f094579d78} executeQuery: Code: 42. DB::Exception: Aggregate function max requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 845, line 847) (in query: SELECT max();) 2025.06.13 15:44:13.345688 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function max requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.422894 [ 3895 ] {103f3923-93a5-4f30-a66a-426e3317e79f} executeQuery: Code: 36. DB::Exception: The size of bloom filter cannot be more than 1073741824. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33120) (comment: 01384_bloom_filter_bad_arguments.sql) (query 8, line 10) (in query: CREATE TABLE test (`a` String, INDEX a a TYPE tokenbf_v1(4294967295, 2, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 47927, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.918639600276947, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 216989707, compact_parts_max_bytes_to_buffer = 272576184, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 27423040, merge_max_block_size = 24504, old_parts_lifetime = 165., prefer_fetch_merged_part_size_threshold = 2095659496, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 12812015, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 57, 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 = 73932, primary_key_compress_block_size = 22588, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c81c0f 5. ./build_docker/./src/Interpreters/BloomFilter.cpp:32: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x000000002dc3ad99 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:819: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000030ea57e6 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7a7e7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:44:13.433811 [ 3895 ] {} TCPHandler: Code: 36. DB::Exception: The size of bloom filter cannot be more than 1073741824. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c81c0f 5. ./build_docker/./src/Interpreters/BloomFilter.cpp:32: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x000000002dc3ad99 6. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:819: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000030ea57e6 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:808: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000030c7a7e7 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:869: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x0000000030c7186d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:517: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f874 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:44:13.487447 [ 5978 ] {738edf10-9759-4933-87a2-2a6f35899e4d} executeQuery: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 628, line 629) (in query: SELECT globalNullInIgnoreSet(-1);) 2025.06.13 15:44:13.495178 [ 8431 ] {8aa0a613-fefe-4361-9893-fbb8cf219450} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 0, should be 2: In scope SELECT max2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 846, line 848) (in query: SELECT max2();) 2025.06.13 15:44:13.513198 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.516329 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 0, should be 2: In scope SELECT max2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.585138 [ 5978 ] {c0a284cc-1f90-421d-b403-23d6e50bea69} executeQuery: Code: 36. DB::Exception: Argument of function globalVariable must be constant string: In scope SELECT globalVariable(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 629, line 630) (in query: SELECT globalVariable(-1);) 2025.06.13 15:44:13.591028 [ 8442 ] {45178afa-2fcf-4b54-afc4-b965d5ab34a9} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UUID. Actual Nullable(Nothing): In scope SELECT toUUIDOrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1486, line 1488) (in query: SELECT toUUIDOrDefault(NULL, NULL);) 2025.06.13 15:44:13.593802 [ 8431 ] {a986c78a-f89a-4ab8-93fa-f0eea12a82e2} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 847, line 849) (in query: SELECT maxIntersections();) 2025.06.13 15:44:13.597282 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: Argument of function globalVariable must be constant string: In scope SELECT globalVariable(-1). (BAD_ARGUMENTS) 2025.06.13 15:44:13.600304 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.602321 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UUID. Actual Nullable(Nothing): In scope SELECT toUUIDOrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.06.13 15:44:13.673496 [ 8431 ] {e613fc87-da53-4b21-82ab-3c795a6e3412} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 848, line 850) (in query: SELECT maxIntersectionsPosition();) 2025.06.13 15:44:13.685597 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.693666 [ 5978 ] {9bdb19d8-7bc7-48b1-8bad-c365e92f27d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 1, should be 4: In scope SELECT greatCircleAngle(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 630, line 631) (in query: SELECT greatCircleAngle(-1);) 2025.06.13 15:44:13.704544 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 1, should be 4: In scope SELECT greatCircleAngle(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.818107 [ 8431 ] {61849d30-5589-41d6-8e39-d68b33eb36ea} executeQuery: Code: 42. DB::Exception: Aggregate function maxMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 849, line 851) (in query: SELECT maxMappedArrays();) 2025.06.13 15:44:13.819679 [ 5978 ] {21c56408-a9ff-4523-b1ab-56b679c316cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 1, should be 4: In scope SELECT greatCircleDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 631, line 632) (in query: SELECT greatCircleDistance(-1);) 2025.06.13 15:44:13.832327 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 1, should be 4: In scope SELECT greatCircleDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.834537 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function maxMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.877106 [ 18377 ] {a4886957-e9b5-4947-9e42-c4b6aa6f9e3a} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41628) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:13.910957 [ 18377 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:13.981060 [ 5978 ] {a669845b-d21b-4665-9c94-dabdcae2b730} executeQuery: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 1, should be 2: In scope SELECT greater(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 632, line 633) (in query: SELECT greater(-1);) 2025.06.13 15:44:13.991042 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 1, should be 2: In scope SELECT greater(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:13.998825 [ 8431 ] {c016be5c-2b52-4f64-8db3-c30bd80edc47} executeQuery: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 850, line 852) (in query: SELECT meanZTest();) 2025.06.13 15:44:14.009338 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:14.079271 [ 5978 ] {d4a9f2d3-1f65-45ef-9168-8da694f5c6a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 1, should be 2: In scope SELECT greaterOrEquals(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 633, line 634) (in query: SELECT greaterOrEquals(-1);) 2025.06.13 15:44:14.107569 [ 8431 ] {65c28024-dfdd-4113-a3c4-b36f1601c2d9} executeQuery: Code: 35. DB::Exception: Aggregate function quantile requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 851, line 853) (in query: SELECT median();) 2025.06.13 15:44:14.108885 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 1, should be 2: In scope SELECT greaterOrEquals(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:14.140597 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantile requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:14.241887 [ 8431 ] {24d0284c-c10f-4276-b0b6-12c20fa60965} executeQuery: Code: 42. DB::Exception: Aggregate function quantileBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 852, line 854) (in query: SELECT medianBFloat16();) 2025.06.13 15:44:14.275988 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:14.360779 [ 8442 ] {69baab8d-c4cb-4517-94cc-4f5684e9f75a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1490, line 1492) (in query: SELECT toUnixTimestamp64Micro(NULL, NULL);) 2025.06.13 15:44:14.393208 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:14.399160 [ 8431 ] {01da8efe-6165-4fac-ae64-0b5bd77cf87e} executeQuery: Code: 35. DB::Exception: Aggregate function quantileBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 853, line 855) (in query: SELECT medianBFloat16Weighted();) 2025.06.13 15:44:14.412510 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:14.500973 [ 8442 ] {25642bbd-f079-46fc-8bd8-a02db040fab4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1491, line 1493) (in query: SELECT toUnixTimestamp64Milli(NULL, NULL);) 2025.06.13 15:44:14.511879 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:14.621225 [ 8431 ] {878285e9-f509-4277-87fe-73a98d9c65d2} executeQuery: Code: 35. DB::Exception: Aggregate function quantileDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 854, line 856) (in query: SELECT medianDD();) 2025.06.13 15:44:14.627637 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:14.700931 [ 5978 ] {561bd7c0-da0a-4cec-9982-082b9f36e7b2} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 636, line 637) (in query: SELECT groupArrayInsertAt(-1);) 2025.06.13 15:44:14.702759 [ 8442 ] {25727c29-e8d5-4a35-8d64-2edb81a196e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1492, line 1494) (in query: SELECT toUnixTimestamp64Nano(NULL, NULL);) 2025.06.13 15:44:14.707866 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:14.729644 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:14.735777 [ 8431 ] {6f2c4e3f-ae82-40b8-adc5-63f1b7f2db6e} executeQuery: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 855, line 857) (in query: SELECT medianDeterministic();) 2025.06.13 15:44:14.749590 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:14.810158 [ 18510 ] {562130ca-e510-4427-9ab7-a62cde87bc88} executeQuery: Code: 36. DB::Exception: Codec Delta is not applicable for String because the data type is not of fixed size. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34034) (comment: 01504_compression_multiple_streams.sql) (query 37, line 87) (in query: -- validation still works, non-sense codecs checked CREATE TABLE columns_with_multiple_streams_bad_case ( field0 Nullable(String) CODEC(Delta, LZ4) ) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Compression/CompressionCodecDelta.cpp:177: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:ne190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x0000000032dc2ad9 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000032df8dc3 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:57: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5de441 9. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 10. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000032df671c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5c1a1 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5e45a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:44:14.831178 [ 5978 ] {8b535349-3904-4eb4-beff-808ef5602ebd} executeQuery: Code: 43. DB::Exception: Aggregate function groupArrayIntersect accepts only array type argument. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 637, line 638) (in query: SELECT groupArrayIntersect(-1);) 2025.06.13 15:44:14.831324 [ 8442 ] {1bd961c4-a002-4b17-b5a2-c2015a08038a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Second(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1493, line 1495) (in query: SELECT toUnixTimestamp64Second(NULL, NULL);) 2025.06.13 15:44:14.843519 [ 18510 ] {} TCPHandler: Code: 36. DB::Exception: Codec Delta is not applicable for String because the data type is not of fixed size. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Compression/CompressionCodecDelta.cpp:177: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:ne190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x0000000032dc2ad9 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000032df8dc3 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:57: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5de441 9. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 10. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000032df671c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5c1a1 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5e45a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:44:14.845026 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Second(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:14.846224 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function groupArrayIntersect accepts only array type argument. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:14.869858 [ 8431 ] {78c880ec-86d9-4727-ad5a-c8221f40b804} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 856, line 858) (in query: SELECT medianExact();) 2025.06.13 15:44:14.877538 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:14.944009 [ 8442 ] {ae8d9349-7c3a-45ce-8e2a-729f644f0fd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT toValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1494, line 1496) (in query: SELECT toValidUTF8(NULL, NULL);) 2025.06.13 15:44:14.944294 [ 5978 ] {14bf4b38-8265-4a2a-b42b-a62105702c6d} executeQuery: Code: 36. DB::Exception: groupArrayLast make sense only with max_elems (groupArrayLast(max_elems)()). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 638, line 639) (in query: SELECT groupArrayLast(-1);) 2025.06.13 15:44:14.953281 [ 8431 ] {78a0134c-c056-47c0-96c2-c5030696afbb} executeQuery: Code: 35. DB::Exception: Aggregate function quantileExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 857, line 859) (in query: SELECT medianExactHigh();) 2025.06.13 15:44:14.953824 [ 18510 ] {c155d01a-d228-44ec-929a-fff97ea62cf3} executeQuery: Code: 431. DB::Exception: T64 codec is not supported for specified type String. (ILLEGAL_SYNTAX_FOR_CODEC_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34034) (comment: 01504_compression_multiple_streams.sql) (query 38, line 94) (in query: CREATE TABLE columns_with_multiple_streams_bad_case ( field0 Tuple(Array(UInt64), String) CODEC(T64, LZ4) ) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Compression/CompressionCodecT64.cpp:775: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:ne190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x0000000032dd56c4 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000032df8dc3 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 8. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5daf18 9. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c682ec1 10. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 11. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000032df671c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5c1a1 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5e45a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:44:14.962320 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: groupArrayLast make sense only with max_elems (groupArrayLast(max_elems)()). (BAD_ARGUMENTS) 2025.06.13 15:44:14.966179 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT toValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:14.988128 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:15.013515 [ 18510 ] {} TCPHandler: Code: 431. DB::Exception: T64 codec is not supported for specified type String. (ILLEGAL_SYNTAX_FOR_CODEC_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Compression/CompressionCodecT64.cpp:775: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:ne190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x0000000032dd56c4 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000032df8dc3 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 8. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c5daf18 9. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002c682ec1 10. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 11. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000032df671c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5c1a1 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5e45a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:44:15.117132 [ 8431 ] {974be547-8781-48b7-b990-ed277483ea02} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 858, line 860) (in query: SELECT medianExactLow();) 2025.06.13 15:44:15.130487 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:15.216336 [ 8431 ] {d3399d4c-469a-4efa-91e2-2797284e8f60} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 859, line 861) (in query: SELECT medianExactWeighted();) 2025.06.13 15:44:15.235966 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:15.330150 [ 8431 ] {f8c0ac62-80cd-4ef5-b0e8-4a23165ec422} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactWeightedInterpolated requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 860, line 862) (in query: SELECT medianExactWeightedInterpolated();) 2025.06.13 15:44:15.358405 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactWeightedInterpolated requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:15.473811 [ 8431 ] {0cb10f05-4fa8-41c1-a426-3edec53a6a30} executeQuery: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 861, line 863) (in query: SELECT medianGK();) 2025.06.13 15:44:15.488187 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:15.609415 [ 5978 ] {fe47a4e8-4c4f-4359-8539-69251848b014} executeQuery: Code: 42. DB::Exception: Incorrect number of parameters for aggregate function groupArraySample, should be 1 or 2. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 641, line 642) (in query: SELECT groupArraySample(-1);) 2025.06.13 15:44:15.616801 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of parameters for aggregate function groupArraySample, should be 1 or 2. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:15.636406 [ 8431 ] {f8ff5d4e-0849-4903-94a9-45d39aed7426} executeQuery: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 862, line 864) (in query: SELECT medianInterpolatedWeighted();) 2025.06.13 15:44:15.655579 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:15.704645 [ 8431 ] {c59f5774-0187-44c4-8ad4-961e9425b0dd} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 863, line 865) (in query: SELECT medianTDigest();) 2025.06.13 15:44:15.719637 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:15.818431 [ 5978 ] {5cc6deae-f9ca-493d-af98-159564c55fc1} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should have limit argument. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 642, line 643) (in query: SELECT groupArraySorted(-1);) 2025.06.13 15:44:15.833352 [ 8431 ] {0c9d8069-b1c1-4ed1-b36e-a8f311c66d7e} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 864, line 866) (in query: SELECT medianTDigestWeighted();) 2025.06.13 15:44:15.837283 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should have limit argument. (BAD_ARGUMENTS) 2025.06.13 15:44:15.844034 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:15.928913 [ 8431 ] {529cdc87-57de-4137-99eb-a82475099c93} executeQuery: Code: 35. DB::Exception: Aggregate function quantileTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 865, line 867) (in query: SELECT medianTiming();) 2025.06.13 15:44:15.935153 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:16.091912 [ 8431 ] {88784c97-5c50-4680-92f5-eb8b95cb2c33} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 866, line 868) (in query: SELECT medianTimingWeighted();) 2025.06.13 15:44:16.186453 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:16.232530 [ 18377 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:16.382361 [ 18377 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:16.446883 [ 18377 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:16.476439 [ 8431 ] {e8ec930d-ef7d-4ff7-9bdb-3c700c1a6318} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT mid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 868, line 870) (in query: SELECT mid();) 2025.06.13 15:44:16.481919 [ 18377 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:16.492898 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT mid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:16.515064 [ 5112 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:16.528002 [ 3894 ] {87ad24e6-18b7-44fe-8bba-b5e4df03e341} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58370) (comment: 02021_create_database_with_comment.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_7;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:16.539430 [ 3894 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:16.558412 [ 5112 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:16.563700 [ 8431 ] {20980aec-076d-4130-8506-4a1620cc6e98} executeQuery: Code: 42. DB::Exception: Aggregate function min requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 869, line 871) (in query: SELECT min();) 2025.06.13 15:44:16.591958 [ 8442 ] {b9fd4b00-673f-435d-8a18-752daa5e7f48} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT today(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1503, line 1505) (in query: SELECT today(NULL, NULL);) 2025.06.13 15:44:16.593066 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function min requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:16.603211 [ 5112 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:16.614927 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT today(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:16.634356 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:16.703910 [ 5112 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:16.748965 [ 8431 ] {cc8d8303-3d00-44b7-9505-3a89712cb218} executeQuery: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 0, should be 2: In scope SELECT min2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 870, line 872) (in query: SELECT min2();) 2025.06.13 15:44:16.765284 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 0, should be 2: In scope SELECT min2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:16.767654 [ 8442 ] {171e5ee0-3f34-43d3-b4ec-d7bba38c10e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 2, should be 1: In scope SELECT tokens(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1504, line 1506) (in query: SELECT tokens(NULL, NULL);) 2025.06.13 15:44:16.774341 [ 4172 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:16.785449 [ 3821 ] {38bbb49c-c8e5-4e3a-97b1-3533be283c53::all_5_6_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:16.796258 [ 3821 ] {f369e638-3a74-4685-9057-e2396c938d20} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41746) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:16.812118 [ 3821 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:16.814733 [ 4172 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:16.850687 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 2, should be 1: In scope SELECT tokens(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:16.852001 [ 8431 ] {c809b003-9fc4-4bb7-b57f-c858b4a59c3e} executeQuery: Code: 42. DB::Exception: Aggregate function minMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 871, line 873) (in query: SELECT minMappedArrays();) 2025.06.13 15:44:16.858690 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function minMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:16.924286 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:16.975814 [ 8431 ] {5c29a60a-a936-47d8-a45d-76510be82138} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 0, should be 5: In scope SELECT minSampleSizeContinous(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 872, line 874) (in query: SELECT minSampleSizeContinous();) 2025.06.13 15:44:16.999202 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 0, should be 5: In scope SELECT minSampleSizeContinous(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:17.012456 [ 5978 ] {5d432812-8cff-4166-947d-a480b48ac6d4} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument for aggregate function groupBitmapAnd. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 647, line 648) (in query: SELECT groupBitmapAnd(-1);) 2025.06.13 15:44:17.023065 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument for aggregate function groupBitmapAnd. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:17.032367 [ 4172 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.063038 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.071497 [ 8431 ] {74913872-bccd-4b93-9f9b-c81666c0e86f} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 0, should be 5: In scope SELECT minSampleSizeContinuous(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 873, line 875) (in query: SELECT minSampleSizeContinuous();) 2025.06.13 15:44:17.077830 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 0, should be 5: In scope SELECT minSampleSizeContinuous(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:17.092973 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.112557 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.126262 [ 5978 ] {bb0cebe8-ef0d-4753-9ff4-1c50baf67239} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument for aggregate function groupBitmapOr. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 648, line 649) (in query: SELECT groupBitmapOr(-1);) 2025.06.13 15:44:17.135666 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument for aggregate function groupBitmapOr. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:17.144775 [ 8431 ] {e6aa0e23-ec04-4f79-a78b-5a9bab429ef9} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 0, should be 4: In scope SELECT minSampleSizeConversion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 874, line 876) (in query: SELECT minSampleSizeConversion();) 2025.06.13 15:44:17.146769 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.176066 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 0, should be 4: In scope SELECT minSampleSizeConversion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:17.216365 [ 5978 ] {71036ee5-baa8-4233-9595-e607190b0b71} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument for aggregate function groupBitmapXor. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 649, line 650) (in query: SELECT groupBitmapXor(-1);) 2025.06.13 15:44:17.233699 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument for aggregate function groupBitmapXor. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:17.238703 [ 8442 ] {574120a5-c22e-477f-8342-0a672cbc062e} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 2, should be 1: In scope SELECT topLevelDomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1507, line 1509) (in query: SELECT topLevelDomain(NULL, NULL);) 2025.06.13 15:44:17.242831 [ 8431 ] {69a4c4f2-a489-42c8-b681-d7f4827e2708} executeQuery: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 0, should be 2: In scope SELECT minus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 875, line 877) (in query: SELECT minus();) 2025.06.13 15:44:17.243068 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 2, should be 1: In scope SELECT topLevelDomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:17.245717 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.256868 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 0, should be 2: In scope SELECT minus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:17.283825 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.363206 [ 8431 ] {e54bc8b8-64e8-4628-864c-4473f5aebbf9} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 0, should be 2: In scope SELECT mismatches(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 876, line 878) (in query: SELECT mismatches();) 2025.06.13 15:44:17.363939 [ 8442 ] {aa2bbf3f-5567-41b7-bf29-43573b15482f} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 2, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1508, line 1510) (in query: SELECT topLevelDomainRFC(NULL, NULL);) 2025.06.13 15:44:17.369305 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.369807 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 2, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:17.400143 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.428494 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.442773 [ 8442 ] {0f7dce67-674e-4a52-a6dd-59e981d3d343} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 2, should be 0: In scope SELECT transactionID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1509, line 1511) (in query: SELECT transactionID(NULL, NULL);) 2025.06.13 15:44:17.450169 [ 5163 ] {b3e7a333-2d72-475e-9799-1b797dffb4f4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=877, jobs=840). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32992) (comment: 02366_kql_func_string.sql) (query 49, line 73) (in query: print '-- Customers | where Occupation !has \'Skilled\'';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:17.469573 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 0, should be 2: In scope SELECT mismatches(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:17.532196 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.545120 [ 5163 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=877, jobs=840). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:17.550114 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 2, should be 0: In scope SELECT transactionID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:17.580283 [ 8431 ] {6411ce9f-ffdc-427d-b890-1ba59ae2a2c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 0, should be 2: In scope SELECT mod(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 877, line 879) (in query: SELECT mod();) 2025.06.13 15:44:17.580381 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.595393 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 0, should be 2: In scope SELECT mod(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:17.622050 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.634867 [ 8442 ] {fde783f8-a61e-4acf-8419-bc9541cad0ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1510, line 1512) (in query: SELECT transactionLatestSnapshot(NULL, NULL);) 2025.06.13 15:44:17.673135 [ 8431 ] {a536974a-a1b4-4b3e-a795-b75b4c06a340} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 0, should be 2: In scope SELECT modulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 878, line 880) (in query: SELECT modulo();) 2025.06.13 15:44:17.688460 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.694965 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:17.696853 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 0, should be 2: In scope SELECT modulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:17.718721 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.777251 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.778655 [ 8442 ] {8151e7e4-a9ed-4839-8378-6301d10995c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1511, line 1513) (in query: SELECT transactionOldestSnapshot(NULL, NULL);) 2025.06.13 15:44:17.786106 [ 5978 ] {534528ad-92fc-44f6-b055-a5bcd84d4df4} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3CellAreaM2. Must be UInt64: In scope SELECT h3CellAreaM2(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 653, line 654) (in query: SELECT h3CellAreaM2(-1);) 2025.06.13 15:44:17.788029 [ 8431 ] {d08d2341-8471-402b-8fce-074e54e5b4bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 0, should be 2: In scope SELECT moduloLegacy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 879, line 881) (in query: SELECT moduloLegacy();) 2025.06.13 15:44:17.804042 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:17.804187 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3CellAreaM2. Must be UInt64: In scope SELECT h3CellAreaM2(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:17.807378 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 0, should be 2: In scope SELECT moduloLegacy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:17.812485 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.846130 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.896974 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:17.923564 [ 5978 ] {62c71112-69d8-451a-af1f-cf7a324d3f02} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3CellAreaRads2. Must be UInt64: In scope SELECT h3CellAreaRads2(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 654, line 655) (in query: SELECT h3CellAreaRads2(-1);) 2025.06.13 15:44:17.929427 [ 8101 ] {07553204-1d63-49dd-8adc-63bff69da714} executeQuery: Code: 117. DB::Exception: Incorrect size (0) in groupBitmap.: In scope SELECT CAST('\0', 'AggregateFunction(groupBitmap, UInt32)'). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41796) (comment: 02688_aggregate_states.sql) (query 1, line 1) (in query: SELECT '\x01\x00'::AggregateFunction(groupBitmap, UInt32);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./src/AggregateFunctions/AggregateFunctionGroupBitmapData.h:127: _ZN2DB25RoaringBitmapWithSmallSetIjLDu32EE4readERNS_10ReadBufferE @ 0x0000000027b80ff1 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c533e4a 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5343ad 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b01d123 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:44:17.930398 [ 8442 ] {9c655000-3c81-4ea3-a008-b0dbf24334f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 2, should be 3 or 4: In scope SELECT transform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1512, line 1514) (in query: SELECT transform(NULL, NULL);) 2025.06.13 15:44:17.944328 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3CellAreaRads2. Must be UInt64: In scope SELECT h3CellAreaRads2(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:17.947654 [ 8101 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect size (0) in groupBitmap.: In scope SELECT CAST('\0', 'AggregateFunction(groupBitmap, UInt32)'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./src/AggregateFunctions/AggregateFunctionGroupBitmapData.h:127: _ZN2DB25RoaringBitmapWithSmallSetIjLDu32EE4readERNS_10ReadBufferE @ 0x0000000027b80ff1 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c533e4a 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5343ad 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b01d123 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:44:17.960119 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 2, should be 3 or 4: In scope SELECT transform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:17.961703 [ 8431 ] {1083a1d8-e5c6-4dc5-86d7-3b4d08a1c00d} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 0, should be 2: In scope SELECT moduloOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 880, line 882) (in query: SELECT moduloOrZero();) 2025.06.13 15:44:17.969604 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 0, should be 2: In scope SELECT moduloOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:18.016920 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.060350 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.068476 [ 5978 ] {3e504d8f-7981-42f6-83e8-32a2e59520ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 1, should be 2: In scope SELECT h3Distance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 655, line 656) (in query: SELECT h3Distance(-1);) 2025.06.13 15:44:18.077608 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 1, should be 2: In scope SELECT h3Distance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:18.092227 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.095193 [ 8431 ] {2d3cce9b-221b-425f-9bd5-9db805516ebb} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 0, should be 1: In scope SELECT monthName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 881, line 883) (in query: SELECT monthName();) 2025.06.13 15:44:18.101523 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 0, should be 1: In scope SELECT monthName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:18.103306 [ 8442 ] {20fe0bc0-4028-43a7-be36-6e751c0c4940} executeQuery: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 2, should be 3: In scope SELECT translate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1513, line 1515) (in query: SELECT translate(NULL, NULL);) 2025.06.13 15:44:18.119939 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 2, should be 3: In scope SELECT translate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:18.131366 [ 8101 ] {0cb48b03-8f71-451a-bf48-4a14f528f7f9} executeQuery: std::exception. Code: 1001, type: std::runtime_error, e.what() = ran out of bytes (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41796) (comment: 02688_aggregate_states.sql) (query 2, line 2) (in query: SELECT '\x01\x01\x01'::AggregateFunction(groupBitmap, UInt64);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./contrib/llvm-project/libcxx/src/support/runtime/stdexcept_default.ipp:34: std::runtime_error::runtime_error(char const*) @ 0x0000000038faa3be 2. ./contrib/croaring/cpp/roaring64map.hh:1186: roaring::Roaring64Map::readSafe(char const*, unsigned long) @ 0x0000000027b82d1c 3. ./src/AggregateFunctions/AggregateFunctionGroupBitmapData.h:136: _ZN2DB25RoaringBitmapWithSmallSetImLDu32EE4readERNS_10ReadBufferE @ 0x0000000027b8214e 4. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c533e4a 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5343ad 6. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 7. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b01d123 9. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:44:18.135271 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.181714 [ 5978 ] {961d09bc-e4e4-497e-a1e9-348f7102e0b4} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3EdgeAngle. Must be UInt8: In scope SELECT h3EdgeAngle(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 656, line 657) (in query: SELECT h3EdgeAngle(-1);) 2025.06.13 15:44:18.188141 [ 8101 ] {} TCPHandler: Code: 1001. DB::Exception: std::runtime_error: ran out of bytes. (STD_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./contrib/llvm-project/libcxx/src/support/runtime/stdexcept_default.ipp:34: std::runtime_error::runtime_error(char const*) @ 0x0000000038faa3be 2. ./contrib/croaring/cpp/roaring64map.hh:1186: roaring::Roaring64Map::readSafe(char const*, unsigned long) @ 0x0000000027b82d1c 3. ./src/AggregateFunctions/AggregateFunctionGroupBitmapData.h:136: _ZN2DB25RoaringBitmapWithSmallSetImLDu32EE4readERNS_10ReadBufferE @ 0x0000000027b8214e 4. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c533e4a 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5343ad 6. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 7. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b01d123 9. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:44:18.194791 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3EdgeAngle. Must be UInt8: In scope SELECT h3EdgeAngle(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:18.210627 [ 8431 ] {e127e700-2d4d-486a-bae5-698afe77e1b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 0, should be 2: In scope SELECT mortonDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 882, line 884) (in query: SELECT mortonDecode();) 2025.06.13 15:44:18.232118 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.239132 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 0, should be 2: In scope SELECT mortonDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:18.274691 [ 8442 ] {99ca86f2-354c-4636-a19e-58975d23288b} executeQuery: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 2, should be 3: In scope SELECT translateUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1514, line 1516) (in query: SELECT translateUTF8(NULL, NULL);) 2025.06.13 15:44:18.285822 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.289761 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 2, should be 3: In scope SELECT translateUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:18.382876 [ 8101 ] {b34f6009-b6a7-4c65-973d-44c34f108736} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 2. Bytes expected: 32.: In scope SELECT CAST('\0\r', 'AggregateFunction(topK, UInt256)'). (CANNOT_READ_ALL_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41796) (comment: 02688_aggregate_states.sql) (query 3, line 3) (in query: SELECT '\x02\x00\x0d'::AggregateFunction(topK, UInt256);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb202f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b28973 6. ./src/IO/ReadHelpers.h:117: DB::SpaceSaving, HashCRC32>>::Counter::read(DB::ReadBuffer&) @ 0x00000000279be825 7. ./src/Common/SpaceSaving.h:303: DB::SpaceSaving, HashCRC32>>::read(DB::ReadBuffer&) @ 0x00000000279bdd9c 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c533e4a 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5343ad 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b01d123 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:44:18.382829 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.402807 [ 8431 ] {bf7fabf8-00bb-4c7d-b3dc-efa9622297ea} executeQuery: Code: 35. DB::Exception: At least one UInt argument is required for function mortonEncode: In scope SELECT mortonEncode(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 883, line 885) (in query: SELECT mortonEncode();) 2025.06.13 15:44:18.402923 [ 5978 ] {6ba6c2bd-3598-462e-9721-378e0c93cd2a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3EdgeLengthKm. Must be UInt8: In scope SELECT h3EdgeLengthKm(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 657, line 658) (in query: SELECT h3EdgeLengthKm(-1);) 2025.06.13 15:44:18.504088 [ 8101 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 2. Bytes expected: 32.: In scope SELECT CAST('\0\r', 'AggregateFunction(topK, UInt256)'). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000001afb202f 5. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b28973 6. ./src/IO/ReadHelpers.h:117: DB::SpaceSaving, HashCRC32>>::Counter::read(DB::ReadBuffer&) @ 0x00000000279be825 7. ./src/Common/SpaceSaving.h:303: DB::SpaceSaving, HashCRC32>>::read(DB::ReadBuffer&) @ 0x00000000279bdd9c 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c533e4a 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5343ad 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b01d123 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:44:18.609990 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3EdgeLengthKm. Must be UInt8: In scope SELECT h3EdgeLengthKm(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:18.610124 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: At least one UInt argument is required for function mortonEncode: In scope SELECT mortonEncode(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:18.616462 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.656186 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.681285 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.686066 [ 5978 ] {e4050825-e1c7-46d8-858a-bbcdd2200359} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3EdgeLengthM. Must be UInt8: In scope SELECT h3EdgeLengthM(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 658, line 659) (in query: SELECT h3EdgeLengthM(-1);) 2025.06.13 15:44:18.711952 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3EdgeLengthM. Must be UInt8: In scope SELECT h3EdgeLengthM(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:18.717493 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.720271 [ 8101 ] {2a0e7998-bc30-468c-ac22-7113e2c20a4b} executeQuery: Code: 128. DB::Exception: The size of serialized hash table is suspiciously large: 4502748553425166142: In scope SELECT CAST(unhex('bebebebebebebebebebebebebebebebebebebebebebebebebebebebebebebe0c0c3131313131313131313131313173290aee00b300'), 'AggregateFunction(minDistinct, Int8)'). (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41796) (comment: 02688_aggregate_states.sql) (query 4, line 4) (in query: SELECT unhex('bebebebebebebebebebebebebebebebebebebebebebebebebebebebebebebe0c0c3131313131313131313131313173290aee00b300')::AggregateFunction(minDistinct, Int8);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. ./src/Common/HashTable/HashTable.h:1257: HashTable<_BitInt(8), HashTableCell, HashTableNoState>, HashTableNoState, HashTableGrower<4ul>, AllocatorWithStackMemory, 16ul, 1ul>>::read(DB::ReadBuffer&) @ 0x00000000249bb93e 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c533e4a 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5343ad 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b01d123 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:44:18.723638 [ 8431 ] {bdd8a7a9-81f5-453e-adf3-faaa1ec3bb32} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAllIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 884, line 886) (in query: SELECT multiFuzzyMatchAllIndices();) 2025.06.13 15:44:18.744796 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAllIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:18.751126 [ 8101 ] {} TCPHandler: Code: 128. DB::Exception: The size of serialized hash table is suspiciously large: 4502748553425166142: In scope SELECT CAST(unhex('bebebebebebebebebebebebebebebebebebebebebebebebebebebebebebebe0c0c3131313131313131313131313173290aee00b300'), 'AggregateFunction(minDistinct, Int8)'). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. ./src/Common/HashTable/HashTable.h:1257: HashTable<_BitInt(8), HashTableCell, HashTableNoState>, HashTableNoState, HashTableGrower<4ul>, AllocatorWithStackMemory, 16ul, 1ul>>::read(DB::ReadBuffer&) @ 0x00000000249bb93e 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c533e4a 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5343ad 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b01d123 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:44:18.787347 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.828374 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.836294 [ 8431 ] {ebf791d3-3438-4552-b815-e1492f852c87} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 885, line 887) (in query: SELECT multiFuzzyMatchAny();) 2025.06.13 15:44:18.850733 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:18.853877 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.854355 [ 5978 ] {ce6807f6-5c32-408e-9992-96e3b9e5caab} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3ExactEdgeLengthKm. Must be UInt64: In scope SELECT h3ExactEdgeLengthKm(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 659, line 660) (in query: SELECT h3ExactEdgeLengthKm(-1);) 2025.06.13 15:44:18.883472 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.921716 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.928962 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3ExactEdgeLengthKm. Must be UInt64: In scope SELECT h3ExactEdgeLengthKm(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:18.954238 [ 8431 ] {e34bbf37-260e-49eb-a579-d00e9481b44e} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 886, line 888) (in query: SELECT multiFuzzyMatchAnyIndex();) 2025.06.13 15:44:18.961438 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:18.969042 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:18.996882 [ 5978 ] {be38894c-1273-4cff-902e-7cfe54428d0e} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3ExactEdgeLengthM. Must be UInt64: In scope SELECT h3ExactEdgeLengthM(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 660, line 661) (in query: SELECT h3ExactEdgeLengthM(-1);) 2025.06.13 15:44:19.025455 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3ExactEdgeLengthM. Must be UInt64: In scope SELECT h3ExactEdgeLengthM(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:19.033588 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.056662 [ 8431 ] {c9038676-a20c-4dce-909f-8be8fbf33bcc} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 887, line 889) (in query: SELECT multiIf();) 2025.06.13 15:44:19.061038 [ 8101 ] {8b7b271f-8199-423d-97b4-4816b5459de4} executeQuery: Code: 117. DB::Exception: The number of elements 2816 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('01000b0b0b0d0d0d0d7175616e74696c6554696d696e672c20496e743332000300'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41796) (comment: 02688_aggregate_states.sql) (query 5, line 5) (in query: SELECT unhex('01000b0b0b0d0d0d0d7175616e74696c6554696d696e672c20496e743332000300')::AggregateFunction(quantileTiming, Int32);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x000000002548344f 5. ./src/AggregateFunctions/QuantileTiming.h:90: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x0000000025482c62 6. ./src/AggregateFunctions/QuantileTiming.h:713: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x00000000254addc9 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c533e4a 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5343ad 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b01d123 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:44:19.067232 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.067658 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:19.074009 [ 8101 ] {} TCPHandler: Code: 117. DB::Exception: The number of elements 2816 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('01000b0b0b0d0d0d0d7175616e74696c6554696d696e672c20496e743332000300'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x000000002548344f 5. ./src/AggregateFunctions/QuantileTiming.h:90: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x0000000025482c62 6. ./src/AggregateFunctions/QuantileTiming.h:713: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x00000000254addc9 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c533e4a 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5343ad 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b01d123 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:44:19.089453 [ 5978 ] {d42feb97-9b93-4600-bd2d-167ae0aa580b} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3ExactEdgeLengthRads. Must be UInt64: In scope SELECT h3ExactEdgeLengthRads(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 661, line 662) (in query: SELECT h3ExactEdgeLengthRads(-1);) 2025.06.13 15:44:19.112186 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.119575 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3ExactEdgeLengthRads. Must be UInt64: In scope SELECT h3ExactEdgeLengthRads(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:19.143879 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.188629 [ 8431 ] {a396b910-7e94-4a33-ba66-266928c8e3ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 0, should be 2: In scope SELECT multiMatchAllIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 888, line 890) (in query: SELECT multiMatchAllIndices();) 2025.06.13 15:44:19.190145 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.193944 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 0, should be 2: In scope SELECT multiMatchAllIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:19.202911 [ 8101 ] {a96e6d00-d37e-4686-be49-518edf706c1d} executeQuery: Code: 117. DB::Exception: The number of elements 256 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('010001'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41796) (comment: 02688_aggregate_states.sql) (query 6, line 6) (in query: SELECT unhex('010001')::AggregateFunction(quantileTiming, Int32);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x000000002548344f 5. ./src/AggregateFunctions/QuantileTiming.h:90: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x0000000025482c62 6. ./src/AggregateFunctions/QuantileTiming.h:713: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x00000000254addc9 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c533e4a 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5343ad 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b01d123 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:44:19.210236 [ 8101 ] {} TCPHandler: Code: 117. DB::Exception: The number of elements 256 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('010001'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x000000002548344f 5. ./src/AggregateFunctions/QuantileTiming.h:90: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x0000000025482c62 6. ./src/AggregateFunctions/QuantileTiming.h:713: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x00000000254addc9 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c533e4a 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5343ad 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b01d123 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:44:19.234268 [ 5978 ] {75886ea3-878c-41f5-bc86-0ca7428af9c2} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetBaseCell. Must be UInt64: In scope SELECT h3GetBaseCell(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 662, line 663) (in query: SELECT h3GetBaseCell(-1);) 2025.06.13 15:44:19.246399 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetBaseCell. Must be UInt64: In scope SELECT h3GetBaseCell(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:19.266959 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.282633 [ 8431 ] {1dbcb5ac-a4a8-428f-8e48-f7e5002846cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 0, should be 2: In scope SELECT multiMatchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 889, line 891) (in query: SELECT multiMatchAny();) 2025.06.13 15:44:19.287866 [ 8442 ] {9d50838c-3690-436d-8b3d-be00009bbdb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1520, line 1523) (in query: SELECT tryBase58Decode(NULL, NULL);) 2025.06.13 15:44:19.295290 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 0, should be 2: In scope SELECT multiMatchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:19.304208 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:19.306677 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.348956 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.363314 [ 8431 ] {3c122cee-a2bc-422d-9e6e-7e3d2bc7b7a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 0, should be 2: In scope SELECT multiMatchAnyIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 890, line 892) (in query: SELECT multiMatchAnyIndex();) 2025.06.13 15:44:19.369823 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 0, should be 2: In scope SELECT multiMatchAnyIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:19.379212 [ 5005 ] {38bbb49c-c8e5-4e3a-97b1-3533be283c53::all_7_8_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.385178 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.385993 [ 8442 ] {8d9af4f5-352c-4d2e-addc-8ea5d3792821} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1521, line 1524) (in query: SELECT tryBase64Decode(NULL, NULL);) 2025.06.13 15:44:19.395464 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:19.396957 [ 5005 ] {618ad15a-f82f-445b-8008-3b107a1648bc} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41844) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:19.417507 [ 5005 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:19.419490 [ 5978 ] {1e461485-d2dc-4f8c-b07a-cd4472e46a71} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetDestinationIndexFromUnidirectionalEdge. Must be UInt64: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 663, line 664) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge(-1);) 2025.06.13 15:44:19.434943 [ 8431 ] {5421397a-7162-4816-a964-c6c7b434066b} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositions(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 891, line 893) (in query: SELECT multiSearchAllPositions();) 2025.06.13 15:44:19.443945 [ 8101 ] {ad1782a1-a6ed-49d0-b9a7-fe82f1c9de43} executeQuery: Code: 128. DB::Exception: Suspiciously large array size (8753160913407246346) in -ForEach aggregate function: In scope SELECT CAST(unhex('0a00797979797979797979790a0a6e'), 'AggregateFunction(minForEach, Ring)'). (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41796) (comment: 02688_aggregate_states.sql) (query 7, line 7) (in query: SELECT unhex('0a00797979797979797979790a0a6e')::AggregateFunction(minForEach, Ring);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. ./src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:75: DB::AggregateFunctionForEach::ensureAggregateData(char*, unsigned long, DB::Arena&) const @ 0x00000000283188cb 6. ./src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:261: DB::AggregateFunctionForEach::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000283141c8 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c533e4a 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5343ad 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b01d123 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:44:19.517615 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetDestinationIndexFromUnidirectionalEdge. Must be UInt64: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:19.520051 [ 8101 ] {} TCPHandler: Code: 128. DB::Exception: Suspiciously large array size (8753160913407246346) in -ForEach aggregate function: In scope SELECT CAST(unhex('0a00797979797979797979790a0a6e'), 'AggregateFunction(minForEach, Ring)'). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. ./src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:75: DB::AggregateFunctionForEach::ensureAggregateData(char*, unsigned long, DB::Arena&) const @ 0x00000000283188cb 6. ./src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:261: DB::AggregateFunctionForEach::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000283141c8 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002c533e4a 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5343ad 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002b01d123 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:44:19.520429 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.539053 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositions(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:19.554694 [ 8442 ] {7dbf4fa0-b081-4b77-972b-b9081bcacbfa} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1522, line 1525) (in query: SELECT tryBase64URLDecode(NULL, NULL);) 2025.06.13 15:44:19.561938 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:19.562825 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.583290 [ 5978 ] {839b5965-e2f0-41fd-beb0-d48e37905f34} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetFaces. Must be UInt64: In scope SELECT h3GetFaces(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 664, line 665) (in query: SELECT h3GetFaces(-1);) 2025.06.13 15:44:19.589805 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetFaces. Must be UInt64: In scope SELECT h3GetFaces(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:19.590227 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.627214 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.629798 [ 8431 ] {a3329df1-c85a-4918-94d8-906fe5f846ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 892, line 894) (in query: SELECT multiSearchAllPositionsCaseInsensitive();) 2025.06.13 15:44:19.641315 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:19.678804 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.717327 [ 5978 ] {87592805-3857-4ea3-bf7e-642e4488c228} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetIndexesFromUnidirectionalEdge. Must be UInt64: In scope SELECT h3GetIndexesFromUnidirectionalEdge(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 665, line 666) (in query: SELECT h3GetIndexesFromUnidirectionalEdge(-1);) 2025.06.13 15:44:19.718187 [ 8431 ] {b62a173d-250b-41f7-8182-1c0f36c04ee3} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 893, line 895) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8();) 2025.06.13 15:44:19.718805 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.723494 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetIndexesFromUnidirectionalEdge. Must be UInt64: In scope SELECT h3GetIndexesFromUnidirectionalEdge(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:19.732002 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:19.774348 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.794095 [ 8431 ] {a7a1be24-fd04-4308-8425-7150c4a57e21} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 894, line 896) (in query: SELECT multiSearchAllPositionsUTF8();) 2025.06.13 15:44:19.794171 [ 5978 ] {c819b200-26a9-4c9a-aa9a-1589a0369c33} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetOriginIndexFromUnidirectionalEdge. Must be UInt64: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 666, line 667) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge(-1);) 2025.06.13 15:44:19.809113 [ 8442 ] {ac6456de-50f7-41d5-93a6-1ead61566b1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 2, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1524, line 1527) (in query: SELECT tryIdnaEncode(NULL, NULL);) 2025.06.13 15:44:19.812712 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:19.815842 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.816494 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetOriginIndexFromUnidirectionalEdge. Must be UInt64: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:19.826393 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 2, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:19.861859 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.884699 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.903811 [ 8431 ] {c71f5b86-aaad-4479-81bf-8953bffa6d16} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 0, should be 2: In scope SELECT multiSearchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 895, line 897) (in query: SELECT multiSearchAny();) 2025.06.13 15:44:19.913893 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 0, should be 2: In scope SELECT multiSearchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:19.924893 [ 5978 ] {34ab27e7-1b2e-48a7-8862-e6036405d96b} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetPentagonIndexes. Must be UInt8: In scope SELECT h3GetPentagonIndexes(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 667, line 668) (in query: SELECT h3GetPentagonIndexes(-1);) 2025.06.13 15:44:19.931042 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetPentagonIndexes. Must be UInt8: In scope SELECT h3GetPentagonIndexes(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:19.933739 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:19.972209 [ 8442 ] {ec09bc91-f34e-4411-9544-7783752fa0fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 2, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1525, line 1528) (in query: SELECT tryPunycodeDecode(NULL, NULL);) 2025.06.13 15:44:19.990624 [ 5978 ] {9daa3a39-b7c7-4b3d-b990-f7ab7a0b7047} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 1, should be 0: In scope SELECT h3GetRes0Indexes(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 668, line 669) (in query: SELECT h3GetRes0Indexes(-1);) 2025.06.13 15:44:19.993661 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 2, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:19.995622 [ 8431 ] {e91d71bc-e8d7-45f6-86f2-126dd679f4fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 896, line 898) (in query: SELECT multiSearchAnyCaseInsensitive();) 2025.06.13 15:44:19.996885 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.021887 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:20.027937 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 1, should be 0: In scope SELECT h3GetRes0Indexes(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:20.070337 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.108419 [ 8431 ] {be1f29e8-72a4-4c06-966c-cd7a71bd6a08} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 897, line 899) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8();) 2025.06.13 15:44:20.111094 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.123460 [ 5978 ] {ef015e20-2b04-41fa-9b5f-49b39cde39e8} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetResolution. Must be UInt64: In scope SELECT h3GetResolution(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 669, line 670) (in query: SELECT h3GetResolution(-1);) 2025.06.13 15:44:20.144781 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetResolution. Must be UInt64: In scope SELECT h3GetResolution(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:20.152671 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.269421 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:20.283218 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.284888 [ 5978 ] {3152b279-ef8b-4870-8b88-936ca3f9371f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 1, should be 2: In scope SELECT h3GetUnidirectionalEdge(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 670, line 671) (in query: SELECT h3GetUnidirectionalEdge(-1);) 2025.06.13 15:44:20.295121 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 1, should be 2: In scope SELECT h3GetUnidirectionalEdge(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:20.312605 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.331857 [ 8431 ] {9319ba5f-f0f2-400c-8377-87422d6b7997} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 898, line 900) (in query: SELECT multiSearchAnyUTF8();) 2025.06.13 15:44:20.339181 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:20.352718 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.359683 [ 5978 ] {458083e4-e9a3-43f8-9e71-e3a1d3b073b9} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetUnidirectionalEdgeBoundary. Must be UInt64: In scope SELECT h3GetUnidirectionalEdgeBoundary(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 671, line 672) (in query: SELECT h3GetUnidirectionalEdgeBoundary(-1);) 2025.06.13 15:44:20.365407 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetUnidirectionalEdgeBoundary. Must be UInt64: In scope SELECT h3GetUnidirectionalEdgeBoundary(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:20.399462 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.431000 [ 8431 ] {f4eb50ba-2843-4dde-adf7-2163cde5347c} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 899, line 901) (in query: SELECT multiSearchFirstIndex();) 2025.06.13 15:44:20.445935 [ 5005 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.456590 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:20.495198 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.537027 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.551093 [ 5978 ] {7d046ed8-994e-45b3-8dc1-14a7528a40ef} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetUnidirectionalEdgesFromHexagon. Must be UInt64: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 672, line 673) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon(-1);) 2025.06.13 15:44:20.559997 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3GetUnidirectionalEdgesFromHexagon. Must be UInt64: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:20.564107 [ 6234 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.583841 [ 8431 ] {72d56536-c35e-4b43-8cb5-b2358b720876} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 900, line 902) (in query: SELECT multiSearchFirstIndexCaseInsensitive();) 2025.06.13 15:44:20.596952 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:20.597534 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.706978 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.726028 [ 5978 ] {921f997c-7675-489b-9e3c-aa0517406695} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3HexAreaKm2. Must be UInt8: In scope SELECT h3HexAreaKm2(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 673, line 674) (in query: SELECT h3HexAreaKm2(-1);) 2025.06.13 15:44:20.734108 [ 8431 ] {6449529a-565c-43a4-900e-2075ca088c16} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 901, line 903) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8();) 2025.06.13 15:44:20.735609 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3HexAreaKm2. Must be UInt8: In scope SELECT h3HexAreaKm2(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:20.738372 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.740225 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:20.884704 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:20.910347 [ 5978 ] {2bb6737d-3460-4063-9260-4699f92060c1} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3HexAreaM2. Must be UInt8: In scope SELECT h3HexAreaM2(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 674, line 675) (in query: SELECT h3HexAreaM2(-1);) 2025.06.13 15:44:20.921667 [ 8431 ] {35b1060b-6538-47a0-b7ec-725a03846990} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 902, line 904) (in query: SELECT multiSearchFirstIndexUTF8();) 2025.06.13 15:44:20.939906 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3HexAreaM2. Must be UInt8: In scope SELECT h3HexAreaM2(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:20.963002 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:20.977699 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.032361 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.064034 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.080102 [ 5978 ] {d869e1ac-6db9-455a-b20c-b372b20a11fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 1, should be 2: In scope SELECT h3HexRing(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 675, line 676) (in query: SELECT h3HexRing(-1);) 2025.06.13 15:44:21.084589 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 1, should be 2: In scope SELECT h3HexRing(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:21.119986 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.148455 [ 8431 ] {4ff0cd6f-b03a-4a83-acef-dd2947d13998} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPosition(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 903, line 905) (in query: SELECT multiSearchFirstPosition();) 2025.06.13 15:44:21.152904 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPosition(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:21.177881 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.236928 [ 8431 ] {4c844cd0-c7a3-4af1-9c6c-676339ea98c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 904, line 906) (in query: SELECT multiSearchFirstPositionCaseInsensitive();) 2025.06.13 15:44:21.243898 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.271874 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:21.276888 [ 5978 ] {16770880-625c-4bdc-8655-8a2bf2d8b9ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 1, should be 2: In scope SELECT h3IndexesAreNeighbors(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 676, line 677) (in query: SELECT h3IndexesAreNeighbors(-1);) 2025.06.13 15:44:21.294646 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 1, should be 2: In scope SELECT h3IndexesAreNeighbors(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:21.304010 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.351084 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.395394 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.410872 [ 8431 ] {c6ca4cb0-1c3d-480c-a93f-49f625b7d466} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 905, line 907) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8();) 2025.06.13 15:44:21.411880 [ 5978 ] {77e46261-d5c6-4e00-a275-4314fbce94b5} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3IsPentagon. Must be UInt64: In scope SELECT h3IsPentagon(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 677, line 678) (in query: SELECT h3IsPentagon(-1);) 2025.06.13 15:44:21.435974 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:21.436085 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3IsPentagon. Must be UInt64: In scope SELECT h3IsPentagon(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:21.469701 [ 9644 ] {2b5c1fc6-cc0c-4031-982b-afd170e3cefc} executeQuery: Code: 490. DB::Exception: Value cannot be represented as date because it's out of range: In scope SELECT fromModifiedJulianDay(-678942). (CANNOT_FORMAT_DATETIME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41874) (comment: 01544_fromModifiedJulianDay.sql) (query 7, line 9) (in query: SELECT fromModifiedJulianDay(-678942);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::OrdinalDate::init(long) @ 0x0000000018d45af7 6. DB::GregorianDate::GregorianDate(long) @ 0x0000000018d452a1 7. DB::ExecutableFunctionFromModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae477cc 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:21.479229 [ 9644 ] {} TCPHandler: Code: 490. DB::Exception: Value cannot be represented as date because it's out of range: In scope SELECT fromModifiedJulianDay(-678942). (CANNOT_FORMAT_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::OrdinalDate::init(long) @ 0x0000000018d45af7 6. DB::GregorianDate::GregorianDate(long) @ 0x0000000018d452a1 7. DB::ExecutableFunctionFromModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae477cc 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:21.518374 [ 7755 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.532985 [ 8431 ] {4277095f-8b32-4d3d-b988-0502c82a5640} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 906, line 908) (in query: SELECT multiSearchFirstPositionUTF8();) 2025.06.13 15:44:21.548920 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:21.554818 [ 5978 ] {c69fddd9-5d60-43b7-929a-6cdeffddf819} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3IsResClassIII. Must be UInt64: In scope SELECT h3IsResClassIII(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 678, line 679) (in query: SELECT h3IsResClassIII(-1);) 2025.06.13 15:44:21.561491 [ 7755 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.573972 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3IsResClassIII. Must be UInt64: In scope SELECT h3IsResClassIII(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:21.636876 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.646852 [ 8431 ] {07636718-618c-4240-a4dd-c8867c9a66ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 0, should be 2: In scope SELECT multiply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 907, line 909) (in query: SELECT multiply();) 2025.06.13 15:44:21.647247 [ 8442 ] {80da3957-c2cb-4463-9d7f-0f61043dd820} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1533, line 1536) (in query: SELECT tupleElement(NULL, NULL);) 2025.06.13 15:44:21.674419 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:21.683268 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 0, should be 2: In scope SELECT multiply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:21.684981 [ 5978 ] {f932a0fa-89d4-4e1b-ad48-b77c5e448d4f} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3IsValid. Must be UInt64: In scope SELECT h3IsValid(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 679, line 680) (in query: SELECT h3IsValid(-1);) 2025.06.13 15:44:21.686086 [ 3894 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.705846 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3IsValid. Must be UInt64: In scope SELECT h3IsValid(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:21.713407 [ 7755 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.825021 [ 8431 ] {71389a5d-9d42-4fb6-b465-545d309c5563} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiplyDecimal does not match: 2 or 3 expected: In scope SELECT multiplyDecimal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 908, line 910) (in query: SELECT multiplyDecimal();) 2025.06.13 15:44:21.852325 [ 7755 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.852425 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiplyDecimal does not match: 2 or 3 expected: In scope SELECT multiplyDecimal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:21.859388 [ 5978 ] {a9927e88-032a-46ed-bca2-794959edb8ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 1, should be 2: In scope SELECT h3Line(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 680, line 681) (in query: SELECT h3Line(-1);) 2025.06.13 15:44:21.878246 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 1, should be 2: In scope SELECT h3Line(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:21.883996 [ 7755 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.928362 [ 7755 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.961197 [ 7755 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:21.998416 [ 5978 ] {5a7f14fb-efe2-4ec0-8e1d-c9031188a063} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3NumHexagons. Must be UInt8: In scope SELECT h3NumHexagons(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 681, line 682) (in query: SELECT h3NumHexagons(-1);) 2025.06.13 15:44:22.005122 [ 7755 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.026321 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3NumHexagons. Must be UInt8: In scope SELECT h3NumHexagons(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:22.040380 [ 9644 ] {a477079f-b07e-41c2-a79b-0aaaf78ece93} executeQuery: Code: 490. DB::Exception: Value cannot be represented as date because it's out of range: In scope SELECT fromModifiedJulianDay(2973484). (CANNOT_FORMAT_DATETIME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41874) (comment: 01544_fromModifiedJulianDay.sql) (query 10, line 12) (in query: SELECT fromModifiedJulianDay(2973484);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::OrdinalDate::init(long) @ 0x0000000018d45af7 6. DB::GregorianDate::GregorianDate(long) @ 0x0000000018d452a1 7. DB::ExecutableFunctionFromModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae39f6c 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:22.050314 [ 3931 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.050425 [ 9644 ] {} TCPHandler: Code: 490. DB::Exception: Value cannot be represented as date because it's out of range: In scope SELECT fromModifiedJulianDay(2973484). (CANNOT_FORMAT_DATETIME), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::OrdinalDate::init(long) @ 0x0000000018d45af7 6. DB::GregorianDate::GregorianDate(long) @ 0x0000000018d452a1 7. DB::ExecutableFunctionFromModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae39f6c 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:22.096784 [ 7755 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.139803 [ 18377 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.153202 [ 5978 ] {de2cff42-0b02-4c03-bac1-7157136dd4c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 1, should be 4: In scope SELECT h3PointDistKm(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 682, line 683) (in query: SELECT h3PointDistKm(-1);) 2025.06.13 15:44:22.160713 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 1, should be 4: In scope SELECT h3PointDistKm(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:22.171754 [ 7755 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.211385 [ 7755 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.243172 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.249142 [ 5978 ] {653b5241-d6bb-48a1-8040-95b37d623747} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 1, should be 4: In scope SELECT h3PointDistM(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 683, line 684) (in query: SELECT h3PointDistM(-1);) 2025.06.13 15:44:22.254524 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 1, should be 4: In scope SELECT h3PointDistM(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:22.293529 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.328369 [ 5978 ] {04dbf7bd-c74b-4972-91f0-f7793f61ab13} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 1, should be 4: In scope SELECT h3PointDistRads(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 684, line 685) (in query: SELECT h3PointDistRads(-1);) 2025.06.13 15:44:22.365048 [ 3894 ] {38bbb49c-c8e5-4e3a-97b1-3533be283c53::all_9_10_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.373283 [ 3894 ] {fc78ccac-2b74-4b5a-891c-badcb65ebcc1} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41950) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:22.378106 [ 3894 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:44:22.412230 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 1, should be 4: In scope SELECT h3PointDistRads(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:22.434473 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.470084 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.512002 [ 5978 ] {bab8b6ba-f506-415b-8089-fb66679a1a5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 1, should be 2: In scope SELECT h3ToCenterChild(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 685, line 686) (in query: SELECT h3ToCenterChild(-1);) 2025.06.13 15:44:22.514069 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.522026 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 1, should be 2: In scope SELECT h3ToCenterChild(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:22.547769 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.580103 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.601533 [ 5978 ] {6a19c336-e126-4237-ac1d-79e9c7eac933} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 1, should be 2: In scope SELECT h3ToChildren(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 686, line 687) (in query: SELECT h3ToChildren(-1);) 2025.06.13 15:44:22.628015 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 1, should be 2: In scope SELECT h3ToChildren(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:22.631360 [ 8431 ] {8dcc2505-9ddb-4daf-952e-da2f27b01afd} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 0, should be 1: In scope SELECT negate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 914, line 916) (in query: SELECT negate();) 2025.06.13 15:44:22.639224 [ 18377 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.721712 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 0, should be 1: In scope SELECT negate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:22.748343 [ 5978 ] {31f50cd9-8201-48c0-8e14-7af83167a6b6} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3ToGeo. Must be UInt64: In scope SELECT h3ToGeo(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 687, line 688) (in query: SELECT h3ToGeo(-1);) 2025.06.13 15:44:22.764400 [ 18377 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.766012 [ 8431 ] {36571cab-40df-4997-913d-07f631190470} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 915, line 917) (in query: SELECT neighbor();) 2025.06.13 15:44:22.775362 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3ToGeo. Must be UInt64: In scope SELECT h3ToGeo(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:22.859277 [ 8431 ] {} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:44:22.875155 [ 18377 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.916297 [ 5978 ] {976001ce-68c3-484a-bbd3-9d285df54bed} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3ToGeoBoundary. Must be UInt64: In scope SELECT h3ToGeoBoundary(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 688, line 689) (in query: SELECT h3ToGeoBoundary(-1);) 2025.06.13 15:44:22.932191 [ 8431 ] {ea418c3c-ee20-4ab2-aa36-2a1da383cda4} executeQuery: Code: 35. DB::Exception: Number of arguments for function nested doesn't match: passed 0, should be at least 2: In scope SELECT nested(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 916, line 918) (in query: SELECT nested();) 2025.06.13 15:44:22.933291 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3ToGeoBoundary. Must be UInt64: In scope SELECT h3ToGeoBoundary(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:22.938406 [ 18377 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:22.948942 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function nested doesn't match: passed 0, should be at least 2: In scope SELECT nested(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:22.969749 [ 18377 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.011954 [ 18377 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.042556 [ 8431 ] {69aede1e-9f97-4494-baca-fe50dcfa908e} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 0, should be 1: In scope SELECT netloc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 917, line 919) (in query: SELECT netloc();) 2025.06.13 15:44:23.044300 [ 5978 ] {0b3c4dc8-9d7f-405b-b5cf-07d65124b311} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 1, should be 2: In scope SELECT h3ToParent(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 689, line 690) (in query: SELECT h3ToParent(-1);) 2025.06.13 15:44:23.045900 [ 5163 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.049479 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 0, should be 1: In scope SELECT netloc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:23.060706 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 1, should be 2: In scope SELECT h3ToParent(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:23.079846 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.131296 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.145011 [ 8431 ] {98367640-d294-4c9c-b8f4-c94503401601} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 0, should be 2: In scope SELECT ngramDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 918, line 920) (in query: SELECT ngramDistance();) 2025.06.13 15:44:23.149133 [ 5978 ] {4873226a-3e25-4005-b0b5-525c2bd2cfc2} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3ToString. Must be UInt64: In scope SELECT h3ToString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 690, line 691) (in query: SELECT h3ToString(-1);) 2025.06.13 15:44:23.174946 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 0, should be 2: In scope SELECT ngramDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:23.184690 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3ToString. Must be UInt64: In scope SELECT h3ToString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:23.213334 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.250997 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.311262 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.318198 [ 5978 ] {6bd98a84-a566-4416-a97e-e3062add3f36} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3UnidirectionalEdgeIsValid. Must be UInt64: In scope SELECT h3UnidirectionalEdgeIsValid(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 691, line 692) (in query: SELECT h3UnidirectionalEdgeIsValid(-1);) 2025.06.13 15:44:23.328049 [ 8431 ] {944d4549-5727-4b1e-998d-cf42d5c843c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 919, line 921) (in query: SELECT ngramDistanceCaseInsensitive();) 2025.06.13 15:44:23.355257 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:23.355528 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function h3UnidirectionalEdgeIsValid. Must be UInt64: In scope SELECT h3UnidirectionalEdgeIsValid(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:23.372124 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.470090 [ 8431 ] {80b8db0b-21d4-4b16-b619-0d6193ea1af4} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 920, line 922) (in query: SELECT ngramDistanceCaseInsensitiveUTF8();) 2025.06.13 15:44:23.473647 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.478642 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:23.484676 [ 5978 ] {494c46b0-c662-4ff6-acf6-530cd5c69956} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 1, should be 2: In scope SELECT h3kRing(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 692, line 693) (in query: SELECT h3kRing(-1);) 2025.06.13 15:44:23.487128 [ 8442 ] {b7311aab-9102-4ae9-b952-08d558b7b20b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 2, should be 1: In scope SELECT tupleNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1544, line 1547) (in query: SELECT tupleNames(NULL, NULL);) 2025.06.13 15:44:23.503209 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 1, should be 2: In scope SELECT h3kRing(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:23.503542 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.505906 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 2, should be 1: In scope SELECT tupleNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:23.541703 [ 5163 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.588776 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.604612 [ 8431 ] {148ebf5d-630f-4b35-82df-33972892126a} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 921, line 923) (in query: SELECT ngramDistanceUTF8();) 2025.06.13 15:44:23.608806 [ 8442 ] {db6ea58b-2050-46bf-91bd-ff1fe505753b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 2, should be 1: In scope SELECT tupleNegate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1545, line 1548) (in query: SELECT tupleNegate(NULL, NULL);) 2025.06.13 15:44:23.611983 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:23.613574 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 2, should be 1: In scope SELECT tupleNegate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:23.618841 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.644376 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.733570 [ 8431 ] {e9eb101f-5ec7-49ec-9bfd-739cef9d88e3} executeQuery: Code: 35. DB::Exception: Function ngramMinHash expect at least one argument: In scope SELECT ngramMinHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 922, line 924) (in query: SELECT ngramMinHash();) 2025.06.13 15:44:23.765108 [ 5978 ] {88384962-6db2-48f1-9c97-b16ae6f190ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 1, should be 2: In scope SELECT has(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 694, line 695) (in query: SELECT has(-1);) 2025.06.13 15:44:23.769787 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function ngramMinHash expect at least one argument: In scope SELECT ngramMinHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:23.777809 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.780483 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 1, should be 2: In scope SELECT has(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:23.812709 [ 4107 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.837031 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.872885 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.873445 [ 5978 ] {8a532360-4db6-4d9c-bd49-7b923f6a8929} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 1, should be 2: In scope SELECT hasAll(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 695, line 696) (in query: SELECT hasAll(-1);) 2025.06.13 15:44:23.880049 [ 8431 ] {14afa5da-4c04-47b9-8b8a-99123ff094d9} executeQuery: Code: 35. DB::Exception: Function ngramMinHashArg expect at least one argument: In scope SELECT ngramMinHashArg(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 923, line 925) (in query: SELECT ngramMinHashArg();) 2025.06.13 15:44:23.882579 [ 8442 ] {d567d738-66df-4f99-8e35-49c7f6717997} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 2, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1547, line 1550) (in query: SELECT tupleToNameValuePairs(NULL, NULL);) 2025.06.13 15:44:23.890807 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 2, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:23.892040 [ 8432 ] {b9830cd0-7b38-4d88-8053-da41c61e8dd0} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, if(1_UInt8, __table1.dummy, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) :: 0) -> modulo(1_UInt8, if(1_UInt8, __table1.dummy, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String))) Nullable(UInt8) : 2'. (ILLEGAL_DIVISION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41994) (comment: 02901_remove_nullable_crash_analyzer.sql) (query 3, line 4) (in query: SELECT 1 % if(1, dummy, NULL);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::impl_::BinaryOperation, char8_t>::apply<(DB::impl_::OpCase)1>(char8_t const*, char8_t const*, char8_t*, unsigned long) @ 0x000000001e0bf29f 6. void DB::impl_::BinaryOperation, char8_t>::process<(DB::impl_::OpCase)1>(char8_t const*, char8_t const*, char8_t*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001e0bec73 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001e0be30f 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001e0bdb8a 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001e0bc99c 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001e0bba81 11. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001e0b6e29 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001e0b67db 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e0b4bac 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e0b3808 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 22. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 23. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:23.895687 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 1, should be 2: In scope SELECT hasAll(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:23.902565 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashArg expect at least one argument: In scope SELECT ngramMinHashArg(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:23.925153 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.927531 [ 8432 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, if(1_UInt8, __table1.dummy, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) :: 0) -> modulo(1_UInt8, if(1_UInt8, __table1.dummy, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String))) Nullable(UInt8) : 2'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::impl_::BinaryOperation, char8_t>::apply<(DB::impl_::OpCase)1>(char8_t const*, char8_t const*, char8_t*, unsigned long) @ 0x000000001e0bf29f 6. void DB::impl_::BinaryOperation, char8_t>::process<(DB::impl_::OpCase)1>(char8_t const*, char8_t const*, char8_t*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001e0bec73 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001e0be30f 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001e0bdb8a 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001e0bc99c 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001e0bba81 11. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001e0b6e29 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001e0b67db 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e0b4bac 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e0b3808 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 22. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 23. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 31. ? @ 0x00007f2f4224dac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:44:23.988852 [ 8442 ] {5cf55399-1aa3-4793-a2a2-6e8a0aaafb56} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT ucase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1548, line 1551) (in query: SELECT ucase(NULL, NULL);) 2025.06.13 15:44:23.989454 [ 7279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:23.999783 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT ucase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:24.009365 [ 5978 ] {b32c45a6-f6ce-4e92-bb44-6a498e745ffb} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 1, should be 2: In scope SELECT hasAny(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 696, line 697) (in query: SELECT hasAny(-1);) 2025.06.13 15:44:24.014872 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 1, should be 2: In scope SELECT hasAny(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:24.027091 [ 3821 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:24.031556 [ 8431 ] {a14b0f87-6a97-4d87-88fe-a3b74dce8132} executeQuery: Code: 35. DB::Exception: Function ngramMinHashArgCaseInsensitive expect at least one argument: In scope SELECT ngramMinHashArgCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 924, line 926) (in query: SELECT ngramMinHashArgCaseInsensitive();) 2025.06.13 15:44:24.056080 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashArgCaseInsensitive expect at least one argument: In scope SELECT ngramMinHashArgCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:24.081047 [ 9642 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:24.095331 [ 5978 ] {9be1ae44-c0eb-4e77-8922-779bef7142c1} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function hasColumnInTable: In scope SELECT hasColumnInTable(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 697, line 698) (in query: SELECT hasColumnInTable(-1);) 2025.06.13 15:44:24.119245 [ 8442 ] {05825189-cb53-4861-9491-3ea056a7cb18} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 2, should be 1: In scope SELECT unbin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1549, line 1552) (in query: SELECT unbin(NULL, NULL);) 2025.06.13 15:44:24.122339 [ 9642 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:24.124698 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 2, should be 1: In scope SELECT unbin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:24.127471 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function hasColumnInTable: In scope SELECT hasColumnInTable(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:24.170172 [ 8431 ] {3fbd982b-20ee-49b8-b4a8-12cb12536245} executeQuery: Code: 35. DB::Exception: Function ngramMinHashArgCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramMinHashArgCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 925, line 927) (in query: SELECT ngramMinHashArgCaseInsensitiveUTF8();) 2025.06.13 15:44:24.180468 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashArgCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramMinHashArgCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:24.182532 [ 4107 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:24.216295 [ 5163 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:24.240364 [ 8442 ] {51eae6f4-5f89-4663-895b-348c202fda38} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 2, should be 1: In scope SELECT unhex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1550, line 1553) (in query: SELECT unhex(NULL, NULL);) 2025.06.13 15:44:24.244085 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 2, should be 1: In scope SELECT unhex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:24.254561 [ 5163 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:24.254928 [ 5978 ] {0c1ee9d7-626d-4460-8519-1a75a0cd4503} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 1, should be 2: In scope SELECT hasSubsequence(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 698, line 699) (in query: SELECT hasSubsequence(-1);) 2025.06.13 15:44:24.268073 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 1, should be 2: In scope SELECT hasSubsequence(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:24.279669 [ 5163 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:24.292200 [ 8431 ] {c2e70847-e4a8-450f-b7cc-c4088875fa60} executeQuery: Code: 35. DB::Exception: Function ngramMinHashArgUTF8 expect at least one argument: In scope SELECT ngramMinHashArgUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 926, line 928) (in query: SELECT ngramMinHashArgUTF8();) 2025.06.13 15:44:24.305790 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashArgUTF8 expect at least one argument: In scope SELECT ngramMinHashArgUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:24.366547 [ 5978 ] {d809bbd2-630e-45ba-bc72-86fd4b0dd98c} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 699, line 700) (in query: SELECT hasSubsequenceCaseInsensitive(-1);) 2025.06.13 15:44:24.378005 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:24.390548 [ 5163 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:24.435875 [ 8431 ] {8ddf2a33-0cc9-40cc-b6ec-403b2dc8fd73} executeQuery: Code: 35. DB::Exception: Function ngramMinHashCaseInsensitive expect at least one argument: In scope SELECT ngramMinHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 927, line 929) (in query: SELECT ngramMinHashCaseInsensitive();) 2025.06.13 15:44:24.447109 [ 18511 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:24.452726 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashCaseInsensitive expect at least one argument: In scope SELECT ngramMinHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:24.476909 [ 5978 ] {43138d85-62cf-4eda-8866-f0d972eacbad} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 700, line 701) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8(-1);) 2025.06.13 15:44:24.484369 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:24.490952 [ 18511 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:24.533775 [ 18511 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x00000000316ffd94 7. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x00000000315b1f84 8. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b26b1 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:24.567499 [ 8431 ] {80d453db-265a-49eb-aed2-3ef0df06c1d5} executeQuery: Code: 35. DB::Exception: Function ngramMinHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramMinHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 928, line 930) (in query: SELECT ngramMinHashCaseInsensitiveUTF8();) 2025.06.13 15:44:24.587004 [ 5978 ] {8121dfc4-cd36-4851-b148-61e6cf14b89e} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 1, should be 2: In scope SELECT hasSubsequenceUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 701, line 702) (in query: SELECT hasSubsequenceUTF8(-1);) 2025.06.13 15:44:24.591779 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramMinHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:24.607563 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 1, should be 2: In scope SELECT hasSubsequenceUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:24.681361 [ 8431 ] {d1fa4c23-abf1-4f4d-b5e4-3b41e267307d} executeQuery: Code: 35. DB::Exception: Function ngramMinHashUTF8 expect at least one argument: In scope SELECT ngramMinHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 929, line 931) (in query: SELECT ngramMinHashUTF8();) 2025.06.13 15:44:24.699536 [ 5978 ] {b807a274-03e5-432c-bf4d-e643ea43eb6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 1, should be 2: In scope SELECT hasSubstr(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 702, line 703) (in query: SELECT hasSubstr(-1);) 2025.06.13 15:44:24.709296 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashUTF8 expect at least one argument: In scope SELECT ngramMinHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:24.719299 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 1, should be 2: In scope SELECT hasSubstr(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:24.810283 [ 8431 ] {8f5c0abb-c213-4a43-b859-a1a6200ca6f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 0, should be 2: In scope SELECT ngramSearch(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 930, line 932) (in query: SELECT ngramSearch();) 2025.06.13 15:44:24.818887 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 0, should be 2: In scope SELECT ngramSearch(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:24.898248 [ 8431 ] {22726486-09d8-4a38-b8a2-93f631abdd37} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT ngramSearchCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 931, line 933) (in query: SELECT ngramSearchCaseInsensitive();) 2025.06.13 15:44:24.915798 [ 5978 ] {33bfc54c-5ff5-431d-ad89-6aab1fe1d4c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 1, should be 0: In scope SELECT hasThreadFuzzer(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 703, line 704) (in query: SELECT hasThreadFuzzer(-1);) 2025.06.13 15:44:24.924137 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT ngramSearchCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:24.927545 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 1, should be 0: In scope SELECT hasThreadFuzzer(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:24.987746 [ 5978 ] {afd2b121-bf77-43cd-b94d-cb62bba142c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 1, should be 2: In scope SELECT hasToken(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 704, line 705) (in query: SELECT hasToken(-1);) 2025.06.13 15:44:25.004254 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 1, should be 2: In scope SELECT hasToken(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:25.011261 [ 8431 ] {227d02bd-e272-45cf-aa17-c2567a84158c} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 932, line 934) (in query: SELECT ngramSearchCaseInsensitiveUTF8();) 2025.06.13 15:44:25.017540 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:25.064144 [ 5163 ] {67a312a4-08e7-4a0f-bb88-155676d75cbd} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52962) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:25.076677 [ 5163 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:25.142343 [ 8431 ] {0e938e61-40f2-47b3-a7e0-3522289376cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramSearchUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 933, line 935) (in query: SELECT ngramSearchUTF8();) 2025.06.13 15:44:25.176238 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramSearchUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:25.181235 [ 5978 ] {9694f77e-7de2-429a-bac1-7494041e02a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT hasTokenCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 705, line 706) (in query: SELECT hasTokenCaseInsensitive(-1);) 2025.06.13 15:44:25.215362 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT hasTokenCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:25.375069 [ 5978 ] {9449addf-2fc9-47c2-b3f1-f72f22339049} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 1, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 706, line 707) (in query: SELECT hasTokenCaseInsensitiveOrNull(-1);) 2025.06.13 15:44:25.380141 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 1, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:25.381687 [ 8431 ] {4a003ea0-49dd-476e-90bb-8e97c99b0201} executeQuery: Code: 35. DB::Exception: Function ngramSimHash expect at least one argument: In scope SELECT ngramSimHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 934, line 936) (in query: SELECT ngramSimHash();) 2025.06.13 15:44:25.387538 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function ngramSimHash expect at least one argument: In scope SELECT ngramSimHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:25.479821 [ 5978 ] {12e311b6-ff81-4d07-99b0-f1b988dc7eaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 1, should be 2: In scope SELECT hasTokenOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 707, line 708) (in query: SELECT hasTokenOrNull(-1);) 2025.06.13 15:44:25.490411 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 1, should be 2: In scope SELECT hasTokenOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:25.534029 [ 8431 ] {ba52c59e-73dd-4f22-a9d1-0bb02d6f44b5} executeQuery: Code: 35. DB::Exception: Function ngramSimHashCaseInsensitive expect at least one argument: In scope SELECT ngramSimHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 935, line 937) (in query: SELECT ngramSimHashCaseInsensitive();) 2025.06.13 15:44:25.555559 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function ngramSimHashCaseInsensitive expect at least one argument: In scope SELECT ngramSimHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:25.640966 [ 8431 ] {fefd607d-db37-4359-8ce1-5f32ba6c05c2} executeQuery: Code: 35. DB::Exception: Function ngramSimHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramSimHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 936, line 938) (in query: SELECT ngramSimHashCaseInsensitiveUTF8();) 2025.06.13 15:44:25.652887 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function ngramSimHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramSimHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:25.746581 [ 8431 ] {a1c02097-961e-4f1a-bc6e-633f89130d65} executeQuery: Code: 35. DB::Exception: Function ngramSimHashUTF8 expect at least one argument: In scope SELECT ngramSimHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 937, line 939) (in query: SELECT ngramSimHashUTF8();) 2025.06.13 15:44:25.750476 [ 5978 ] {60b4a410-c9a2-42e4-9636-4e6e2bbeca91} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 1, should be 2: In scope SELECT hilbertDecode(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 709, line 710) (in query: SELECT hilbertDecode(-1);) 2025.06.13 15:44:25.751771 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function ngramSimHashUTF8 expect at least one argument: In scope SELECT ngramSimHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:25.793274 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 1, should be 2: In scope SELECT hilbertDecode(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:25.844354 [ 8431 ] {7d728bad-5b93-489c-b848-26a3d2f0bd37} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 0, should be 2: In scope SELECT ngrams(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 938, line 940) (in query: SELECT ngrams();) 2025.06.13 15:44:25.857416 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 0, should be 2: In scope SELECT ngrams(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:25.890718 [ 5978 ] {85e16204-e7cc-496d-8d68-eab243e44c1f} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument for function hilbertEncode, should be a native UInt: In scope SELECT hilbertEncode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 710, line 711) (in query: SELECT hilbertEncode(-1);) 2025.06.13 15:44:25.896519 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument for function hilbertEncode, should be a native UInt: In scope SELECT hilbertEncode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:25.927506 [ 8431 ] {5880ab88-6e15-492b-823b-207b5792bf12} executeQuery: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 939, line 941) (in query: SELECT nonNegativeDerivative();) 2025.06.13 15:44:25.939869 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.094471 [ 5978 ] {ab20e7e1-6551-4953-b514-75ca3085c4eb} executeQuery: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 711, line 712) (in query: SELECT histogram(-1);) 2025.06.13 15:44:26.100047 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.145265 [ 8431 ] {8cb1afb4-102a-4c33-a050-806709a424cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 0, should be 1: In scope SELECT normL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 940, line 942) (in query: SELECT normL1();) 2025.06.13 15:44:26.153112 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 0, should be 1: In scope SELECT normL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.248708 [ 8431 ] {59e6cd70-4161-4b5c-b838-7e9cfa2d07b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 0, should be 1: In scope SELECT normL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 941, line 943) (in query: SELECT normL2();) 2025.06.13 15:44:26.274678 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 0, should be 1: In scope SELECT normL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.330597 [ 8431 ] {77c4b8ad-9535-4fc6-b308-d83861984a60} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 0, should be 1: In scope SELECT normL2Squared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 942, line 944) (in query: SELECT normL2Squared();) 2025.06.13 15:44:26.346030 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 0, should be 1: In scope SELECT normL2Squared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.361145 [ 5978 ] {2028778c-caa4-4560-96ba-c202b9100f9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function hop doesn't match: passed 1, should be 3 or 4: In scope SELECT hop(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 713, line 714) (in query: SELECT hop(-1);) 2025.06.13 15:44:26.369035 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hop doesn't match: passed 1, should be 3 or 4: In scope SELECT hop(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.424840 [ 8442 ] {3f760629-db53-4cf3-be35-4db8f813204e} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT upper(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1561, line 1564) (in query: SELECT upper(NULL, NULL);) 2025.06.13 15:44:26.426744 [ 8431 ] {0e30e574-6fe5-48fb-b8fb-5e81b07a6432} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 0, should be 1: In scope SELECT normLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 943, line 945) (in query: SELECT normLinf();) 2025.06.13 15:44:26.432403 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT upper(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.449197 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 0, should be 1: In scope SELECT normLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.520373 [ 5978 ] {15e385a6-debd-46e5-96bb-0f4a1f577145} executeQuery: Code: 44. DB::Exception: Illegal type of first argument of function hopEnd should be DateTime, Tuple or UInt32: In scope SELECT hopEnd(-1). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 714, line 715) (in query: SELECT hopEnd(-1);) 2025.06.13 15:44:26.529151 [ 5978 ] {} TCPHandler: Code: 44. DB::Exception: Illegal type of first argument of function hopEnd should be DateTime, Tuple or UInt32: In scope SELECT hopEnd(-1). (ILLEGAL_COLUMN) 2025.06.13 15:44:26.549570 [ 8442 ] {c8d8537d-7d79-4847-9624-2af807ef1955} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 2, should be 1: In scope SELECT upperUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1562, line 1565) (in query: SELECT upperUTF8(NULL, NULL);) 2025.06.13 15:44:26.561286 [ 8431 ] {ed59c0ff-cdbc-43bb-b612-4f4b530f4cc1} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 0, should be 2: In scope SELECT normLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 944, line 946) (in query: SELECT normLp();) 2025.06.13 15:44:26.573749 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 2, should be 1: In scope SELECT upperUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.661342 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 0, should be 2: In scope SELECT normLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.706267 [ 5978 ] {19841c56-b21c-4158-99be-70dc5eac68f3} executeQuery: Code: 44. DB::Exception: Illegal type of first argument of function hopStart should be DateTime, Tuple or UInt32: In scope SELECT hopStart(-1). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 715, line 716) (in query: SELECT hopStart(-1);) 2025.06.13 15:44:26.711616 [ 8442 ] {934c06e6-def0-4771-b70a-5585d5619746} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 2, should be 0: In scope SELECT uptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1563, line 1566) (in query: SELECT uptime(NULL, NULL);) 2025.06.13 15:44:26.716442 [ 5978 ] {} TCPHandler: Code: 44. DB::Exception: Illegal type of first argument of function hopStart should be DateTime, Tuple or UInt32: In scope SELECT hopStart(-1). (ILLEGAL_COLUMN) 2025.06.13 15:44:26.718247 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 2, should be 0: In scope SELECT uptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.737474 [ 8431 ] {11544c06-f602-45bc-9deb-c088b3992c34} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 0, should be 1: In scope SELECT normalizeL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 945, line 947) (in query: SELECT normalizeL1();) 2025.06.13 15:44:26.742540 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 0, should be 1: In scope SELECT normalizeL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.780280 [ 5978 ] {761008f9-b302-4daa-97bc-8d940527e502} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 1, should be 0: In scope SELECT hostName(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 716, line 717) (in query: SELECT hostName(-1);) 2025.06.13 15:44:26.792064 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 1, should be 0: In scope SELECT hostName(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.808906 [ 8431 ] {5a3653c3-f4d6-47ab-bd66-317baf4cee8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 0, should be 1: In scope SELECT normalizeL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 946, line 948) (in query: SELECT normalizeL2();) 2025.06.13 15:44:26.815904 [ 8442 ] {feaeaccd-9797-40e5-89b7-7fd00fef46e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1564, line 1567) (in query: SELECT user(NULL, NULL);) 2025.06.13 15:44:26.828568 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 0, should be 1: In scope SELECT normalizeL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.850694 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.969942 [ 8431 ] {d8c690b4-b085-4af9-b5b9-8c7896b5de56} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 0, should be 1: In scope SELECT normalizeLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 947, line 949) (in query: SELECT normalizeLinf();) 2025.06.13 15:44:26.973961 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 0, should be 1: In scope SELECT normalizeLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:26.994207 [ 5978 ] {d3fae5bd-6213-41af-8590-c9ca05bdeabd} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 1, should be 0: In scope SELECT hostname(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 717, line 718) (in query: SELECT hostname(-1);) 2025.06.13 15:44:27.081838 [ 8431 ] {9cb0536e-09e0-4d43-bb8d-87e57bae5427} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 0, should be 2: In scope SELECT normalizeLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 948, line 950) (in query: SELECT normalizeLp();) 2025.06.13 15:44:27.091588 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 0, should be 2: In scope SELECT normalizeLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:27.100736 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 1, should be 0: In scope SELECT hostname(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:27.189258 [ 5978 ] {0778a79a-9086-4090-9e8a-069a04f1a08b} executeQuery: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 1, should be 2: In scope SELECT hypot(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 718, line 719) (in query: SELECT hypot(-1);) 2025.06.13 15:44:27.193990 [ 8431 ] {41103b14-80f0-4151-b106-693b67bbe0d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 0, should be 1: In scope SELECT normalizeQuery(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 949, line 951) (in query: SELECT normalizeQuery();) 2025.06.13 15:44:27.199736 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 1, should be 2: In scope SELECT hypot(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:27.202079 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 0, should be 1: In scope SELECT normalizeQuery(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:27.254191 [ 8431 ] {6f554143-008b-4216-b58b-8a8616ff6ef8} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 0, should be 1: In scope SELECT normalizeQueryKeepNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 950, line 952) (in query: SELECT normalizeQueryKeepNames();) 2025.06.13 15:44:27.267911 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 0, should be 1: In scope SELECT normalizeQueryKeepNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:27.325722 [ 5978 ] {56321703-69be-4858-8309-d94119ff3947} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergBucket doesn't match: passed 1, should be 2: In scope SELECT icebergBucket(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 719, line 720) (in query: SELECT icebergBucket(-1);) 2025.06.13 15:44:27.346757 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergBucket doesn't match: passed 1, should be 2: In scope SELECT icebergBucket(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:27.363532 [ 8431 ] {f32d0f7b-52bc-4e84-82ab-1b92902d35fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 951, line 953) (in query: SELECT normalizeUTF8NFC();) 2025.06.13 15:44:27.374196 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:27.518286 [ 8431 ] {270de30c-c43f-4e84-beb2-8d0d6ef8e849} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 952, line 954) (in query: SELECT normalizeUTF8NFD();) 2025.06.13 15:44:27.530902 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:27.625517 [ 8431 ] {395e9f8c-4db9-4e49-9501-af18a5113d0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFKC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 953, line 955) (in query: SELECT normalizeUTF8NFKC();) 2025.06.13 15:44:27.637056 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFKC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:27.682461 [ 5978 ] {b6935b83-f4b5-4aaa-8fb1-a08a164e8911} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 1, should be 2: In scope SELECT icebergTruncate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 721, line 722) (in query: SELECT icebergTruncate(-1);) 2025.06.13 15:44:27.687492 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 1, should be 2: In scope SELECT icebergTruncate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:27.748065 [ 6234 ] {544a7b9b-ee2b-4928-b9b1-bb1c9c87564e} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53112) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:27.751878 [ 6234 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:27.767638 [ 8431 ] {75a1f013-72e8-4394-8743-eecb182c9278} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFKD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 954, line 956) (in query: SELECT normalizeUTF8NFKD();) 2025.06.13 15:44:27.791914 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFKD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:27.971947 [ 8431 ] {12e09303-31a4-4aad-a01a-92bde30ee2e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 0, should be 1: In scope SELECT normalizedQueryHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 955, line 957) (in query: SELECT normalizedQueryHash();) 2025.06.13 15:44:27.977066 [ 5978 ] {84516f85-8683-4da3-86be-6394832819d6} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function idnaDecode: In scope SELECT idnaDecode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 723, line 724) (in query: SELECT idnaDecode(-1);) 2025.06.13 15:44:27.999361 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 0, should be 1: In scope SELECT normalizedQueryHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:28.006906 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function idnaDecode: In scope SELECT idnaDecode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:28.063334 [ 8442 ] {b2ff4e3c-b855-4c61-9bab-a39bd1906b2f} executeQuery: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1570, line 1573) (in query: SELECT variantElement(NULL, NULL);) 2025.06.13 15:44:28.071844 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:28.153712 [ 5978 ] {b103cc86-fe94-4374-9aa1-10a5744078e8} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function idnaEncode: In scope SELECT idnaEncode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 724, line 725) (in query: SELECT idnaEncode(-1);) 2025.06.13 15:44:28.172448 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function idnaEncode: In scope SELECT idnaEncode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:28.212234 [ 8442 ] {e9f7ccb9-f7cd-4fce-b816-90f4c6883262} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 2, should be 1: In scope SELECT variantType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1571, line 1574) (in query: SELECT variantType(NULL, NULL);) 2025.06.13 15:44:28.227937 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 2, should be 1: In scope SELECT variantType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:28.281829 [ 8431 ] {29b4442a-7684-4419-b939-1f481bb9c02d} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 0, should be 1: In scope SELECT normalizedQueryHashKeepNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 956, line 958) (in query: SELECT normalizedQueryHashKeepNames();) 2025.06.13 15:44:28.289057 [ 5978 ] {91054738-836c-45c8-beb3-2e13db49cdf5} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 1, should be 3: In scope SELECT if(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 725, line 726) (in query: SELECT if(-1);) 2025.06.13 15:44:28.388301 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 0, should be 1: In scope SELECT normalizedQueryHashKeepNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:28.396463 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 1, should be 3: In scope SELECT if(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:28.455975 [ 5978 ] {43404b8b-4c9f-406d-8962-1ff0fa055ffe} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 1, should be 2: In scope SELECT ifNotFinite(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 726, line 727) (in query: SELECT ifNotFinite(-1);) 2025.06.13 15:44:28.460435 [ 8431 ] {af523bd9-4f8e-4bc5-b04f-54578c791eb1} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 0, should be 1: In scope SELECT not(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 957, line 959) (in query: SELECT not();) 2025.06.13 15:44:28.462466 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 1, should be 2: In scope SELECT ifNotFinite(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:28.480176 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 0, should be 1: In scope SELECT not(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:28.573377 [ 5978 ] {55f1aa89-a9fe-46c8-8441-4d199baa9425} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 1, should be 2: In scope SELECT ifNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 727, line 728) (in query: SELECT ifNull(-1);) 2025.06.13 15:44:28.588874 [ 8431 ] {5a7ad244-31dc-4909-87c7-739d6546f36a} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 0, should be 1: In scope SELECT notEmpty(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 958, line 960) (in query: SELECT notEmpty();) 2025.06.13 15:44:28.589887 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 1, should be 2: In scope SELECT ifNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:28.625428 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 0, should be 1: In scope SELECT notEmpty(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:28.695300 [ 8442 ] {23535c61-c6e4-4f8e-9da4-1d53f908f8a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 2, should be 0: In scope SELECT version(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1574, line 1577) (in query: SELECT version(NULL, NULL);) 2025.06.13 15:44:28.720534 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 2, should be 0: In scope SELECT version(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:28.722606 [ 8431 ] {4e8a7958-59ab-4af4-9163-58ed0f702b73} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 0, should be 2: In scope SELECT notEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 959, line 961) (in query: SELECT notEquals();) 2025.06.13 15:44:28.736081 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 0, should be 2: In scope SELECT notEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:28.842963 [ 8431 ] {2485ca04-9be4-4775-980d-5572976186e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 0, should be 2: In scope SELECT notILike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 960, line 962) (in query: SELECT notILike();) 2025.06.13 15:44:28.856663 [ 8442 ] {a89bbe22-3dfa-4440-b881-0b796c665945} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 2, should be 1: In scope SELECT visibleWidth(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1575, line 1578) (in query: SELECT visibleWidth(NULL, NULL);) 2025.06.13 15:44:28.865782 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 0, should be 2: In scope SELECT notILike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:28.865697 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 2, should be 1: In scope SELECT visibleWidth(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:28.944236 [ 5978 ] {f3324c6e-4b22-4140-9a40-0c6f34c05d2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 1, should be 2: In scope SELECT ilike(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 729, line 730) (in query: SELECT ilike(-1);) 2025.06.13 15:44:28.996817 [ 8431 ] {cbe60c46-a4b6-4893-848a-de44c3fc5346} executeQuery: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 961, line 963) (in query: SELECT notIn();) 2025.06.13 15:44:29.008378 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 1, should be 2: In scope SELECT ilike(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:29.031584 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:29.153399 [ 8431 ] {b60a08fd-a070-4e5a-952b-7668acb70096} executeQuery: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 962, line 964) (in query: SELECT notInIgnoreSet();) 2025.06.13 15:44:29.153489 [ 5978 ] {0004e62c-5bd7-428e-89e9-e4e817198d5b} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 730, line 731) (in query: SELECT in(-1);) 2025.06.13 15:44:29.160363 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:29.160610 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:29.235884 [ 5978 ] {649ddb19-a6a1-4e14-ac04-93a61b9fb8f9} executeQuery: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 731, line 732) (in query: SELECT inIgnoreSet(-1);) 2025.06.13 15:44:29.253584 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:29.258801 [ 8431 ] {7df069a2-db5b-4276-82a0-c983f06fecc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 0, should be 2: In scope SELECT notLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 963, line 965) (in query: SELECT notLike();) 2025.06.13 15:44:29.286353 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 0, should be 2: In scope SELECT notLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:29.415156 [ 8431 ] {94db27ea-01da-4e15-8bf0-21bb90f50403} executeQuery: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 964, line 966) (in query: SELECT notNullIn();) 2025.06.13 15:44:29.422350 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:29.637848 [ 8431 ] {2c1880f5-5cf1-4113-8753-b458844b42c7} executeQuery: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 965, line 967) (in query: SELECT notNullInIgnoreSet();) 2025.06.13 15:44:29.645436 [ 5978 ] {72d1d44d-8b38-4e57-9aac-3beb8f8f0266} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 1, should be 2: In scope SELECT indexOf(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 733, line 734) (in query: SELECT indexOf(-1);) 2025.06.13 15:44:29.656763 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:29.665784 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 1, should be 2: In scope SELECT indexOf(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:29.814146 [ 5978 ] {63bf6977-5a4c-447e-8730-6d224950da07} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 1, should be 2: In scope SELECT indexOfAssumeSorted(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 734, line 735) (in query: SELECT indexOfAssumeSorted(-1);) 2025.06.13 15:44:29.829606 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 1, should be 2: In scope SELECT indexOfAssumeSorted(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:30.052454 [ 5978 ] {505e4e79-1813-4b4e-a91b-7cdd89bb90b5} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function initcap: In scope SELECT initcap(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 735, line 736) (in query: SELECT initcap(-1);) 2025.06.13 15:44:30.058913 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function initcap: In scope SELECT initcap(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:30.220168 [ 5978 ] {df65fdb0-c6b0-4251-a983-9154b75ff65e} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function initcapUTF8: In scope SELECT initcapUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 736, line 737) (in query: SELECT initcapUTF8(-1);) 2025.06.13 15:44:30.243964 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function initcapUTF8: In scope SELECT initcapUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:30.386355 [ 5978 ] {064e8cfa-b2de-445c-b3b5-c44ce25570e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 1, should be 0: In scope SELECT initialQueryID(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 737, line 738) (in query: SELECT initialQueryID(-1);) 2025.06.13 15:44:30.406048 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 1, should be 0: In scope SELECT initialQueryID(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:30.542237 [ 5978 ] {ff1b6aed-996b-4b7d-b894-d710aa65c1b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 1, should be 0: In scope SELECT initialQueryStartTime(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 738, line 739) (in query: SELECT initialQueryStartTime(-1);) 2025.06.13 15:44:30.550373 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 1, should be 0: In scope SELECT initialQueryStartTime(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:30.723974 [ 5978 ] {a5d13649-b4a0-45c8-b41d-0ff67f13d1f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 1, should be 0: In scope SELECT initial_query_id(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 739, line 740) (in query: SELECT initial_query_id(-1);) 2025.06.13 15:44:30.748829 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 1, should be 0: In scope SELECT initial_query_id(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:30.871082 [ 5005 ] {f17dbf43-117a-4a26-96c3-0d06b4aa442f} 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.20286.altinityantalya (altinity build)) (from [::1]:53202) (comment: 00445_join_nullable_keys.sql) (query 5, line 15) (in query: SELECT k, a, b FROM ( SELECT number AS k, toString(number) AS a FROM system.numbers LIMIT 10 ) js1 ANY LEFT JOIN ( SELECT nullIf(number, 8) AS k, toString(number) AS b FROM system.numbers LIMIT 5, 10 ) js2 USING (k) ORDER BY k;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf4487 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213d4c9 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:44:30.892051 [ 5005 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf4487 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213d4c9 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:44:30.902034 [ 5978 ] {e0fad364-4717-4e27-984c-5d5d2ae859d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 1, should be 0: In scope SELECT initial_query_start_time(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 740, line 741) (in query: SELECT initial_query_start_time(-1);) 2025.06.13 15:44:30.915920 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 1, should be 0: In scope SELECT initial_query_start_time(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:30.962853 [ 8442 ] {7de9e73e-ff8b-4144-83e6-d50e4f23fd6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT widthBucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1585, line 1588) (in query: SELECT widthBucket(NULL, NULL);) 2025.06.13 15:44:30.984720 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT widthBucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:31.111526 [ 5978 ] {ecedc943-6973-4e2b-9e20-168d8a93561c} executeQuery: Code: 42. DB::Exception: Number of arguments for function initializeAggregation doesn't match: passed 1, should be at least 2.: In scope SELECT initializeAggregation(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 741, line 742) (in query: SELECT initializeAggregation(-1);) 2025.06.13 15:44:31.120066 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initializeAggregation doesn't match: passed 1, should be at least 2.: In scope SELECT initializeAggregation(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:31.212616 [ 8442 ] {6ad89335-9644-41e9-95f9-248c2069f54f} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT width_bucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1586, line 1589) (in query: SELECT width_bucket(NULL, NULL);) 2025.06.13 15:44:31.229264 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT width_bucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:31.242486 [ 8431 ] {4320645a-4d5a-478a-9bd1-ba89dc5455c8} executeQuery: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 972, line 974) (in query: SELECT nth_value();) 2025.06.13 15:44:31.252835 [ 5978 ] {256f71b6-9bb9-4ee0-be85-7d435787484f} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 1, should be 2 or 3: In scope SELECT instr(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 742, line 743) (in query: SELECT instr(-1);) 2025.06.13 15:44:31.282543 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:31.293714 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 1, should be 2 or 3: In scope SELECT instr(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:31.338907 [ 7755 ] {38bbb49c-c8e5-4e3a-97b1-3533be283c53::all_15_16_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030c4f297 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3acc41 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 13. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1afd8 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 16. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 17. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 18. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 19. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:31.365410 [ 7755 ] {5a6f7997-488b-4a2e-9474-407b06e35951} executeQuery: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53260) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030c4f297 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3acc41 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 13. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1afd8 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 16. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 17. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 18. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 19. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:44:31.380599 [ 7755 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030c4f297 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3acc41 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 13. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1afd8 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 16. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 17. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 18. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 19. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:44:31.482286 [ 8431 ] {35205d7e-c9e9-4fd5-94d5-3380754034fb} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 973, line 975) (in query: SELECT ntile();) 2025.06.13 15:44:31.483030 [ 5978 ] {90ee40b7-0e66-4d6c-ab80-302957385bee} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 1, should be 2: In scope SELECT intDiv(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 743, line 744) (in query: SELECT intDiv(-1);) 2025.06.13 15:44:31.489131 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:31.597361 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 1, should be 2: In scope SELECT intDiv(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:31.694345 [ 8431 ] {f39eaf73-f414-4c35-a820-24a19719d220} executeQuery: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 0, should be 2: In scope SELECT nullIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 974, line 976) (in query: SELECT nullIf();) 2025.06.13 15:44:31.728349 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 0, should be 2: In scope SELECT nullIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:31.764642 [ 5978 ] {d442a880-75ae-489d-990b-33aae0eccc2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 1, should be 2: In scope SELECT intDivOrZero(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 744, line 745) (in query: SELECT intDivOrZero(-1);) 2025.06.13 15:44:31.787618 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 1, should be 2: In scope SELECT intDivOrZero(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:31.828296 [ 3821 ] {1cebd4b1-d1c6-453d-95cd-25a779b133cb} executeQuery: Code: 36. DB::Exception: CellId is invalid.: In scope SELECT s2ToGeo(toUInt64(-1)). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52932) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::(anonymous namespace)::FunctionS2ToGeo::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002079bddc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:44:31.841981 [ 3821 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::(anonymous namespace)::FunctionS2ToGeo::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002079bddc 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:44:31.855951 [ 8431 ] {d33ed4b8-0fef-432f-9d74-0f482b9cb63f} executeQuery: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 975, line 977) (in query: SELECT nullIn();) 2025.06.13 15:44:31.865834 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:31.994573 [ 8431 ] {e4bff475-a7e1-4922-9578-6af822b6d969} executeQuery: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 976, line 978) (in query: SELECT nullInIgnoreSet();) 2025.06.13 15:44:31.997827 [ 8442 ] {9ed9c8b0-7897-4386-ad6d-fb708f29049e} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 2, should be 1: In scope SELECT wkt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1589, line 1592) (in query: SELECT wkt(NULL, NULL);) 2025.06.13 15:44:32.023133 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:32.029350 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 2, should be 1: In scope SELECT wkt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:32.113395 [ 8431 ] {f4d9b36b-f6c6-4ffa-a76a-9fd2ca546191} executeQuery: Code: 35. DB::Exception: Number of arguments for function "or" should be at least 2: passed 0: In scope SELECT or(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 977, line 979) (in query: SELECT or();) 2025.06.13 15:44:32.126543 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "or" should be at least 2: passed 0: In scope SELECT or(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:32.209857 [ 3821 ] {8ca5d746-afc3-45c2-9ea4-9e4359c82468} 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.20286.altinityantalya (altinity build)) (from [::1]:52932) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000001afa5f2f 5. DB::(anonymous namespace)::FunctionS2ToGeo::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002079c397 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:44:32.227114 [ 3821 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, int&&, String&&) @ 0x000000001afa5f2f 5. DB::(anonymous namespace)::FunctionS2ToGeo::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000002079c397 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:44:32.365853 [ 8431 ] {573d3949-9540-43ff-93a0-022c8c86450b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlay'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT overlay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 978, line 980) (in query: SELECT overlay();) 2025.06.13 15:44:32.377389 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlay'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT overlay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:32.509008 [ 8431 ] {6b58de33-18b9-4744-b488-6f2c9bd7d7af} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlayUTF8'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT overlayUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 979, line 981) (in query: SELECT overlayUTF8();) 2025.06.13 15:44:32.517383 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlayUTF8'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT overlayUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:32.518481 [ 3821 ] {e0a9abde-b1b7-4ce8-b5f6-8e7aa5ed70db} 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.20286.altinityantalya (altinity build)) (from [::1]:52932) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, double const&, double const&, String&&) @ 0x000000001afa90af 5. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001afa856b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:44:32.539697 [ 3821 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, double const&, double const&, String&&) @ 0x000000001afa90af 5. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001afa856b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:44:32.574088 [ 5978 ] {abc7a33a-c714-47af-9695-c15cc2556bb9} executeQuery: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 749, line 750) (in query: SELECT intervalLengthSum(-1);) 2025.06.13 15:44:32.589087 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:32.604580 [ 8431 ] {0775d592-b323-4ca8-8c85-6f71303cfc14} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 980, line 982) (in query: SELECT parseDateTime();) 2025.06.13 15:44:32.615374 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:32.687140 [ 8431 ] {0fb177c6-b12f-46d0-9be1-3e77e2b4dc22} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffort doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 981, line 983) (in query: SELECT parseDateTime32BestEffort();) 2025.06.13 15:44:32.713158 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffort doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:32.731148 [ 3821 ] {ce019c77-023e-4ada-be18-f9d8fe6d0738} 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.20286.altinityantalya (altinity build)) (from [::1]:52932) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001afa819d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:44:32.741716 [ 3821 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001afa819d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:44:32.809787 [ 8431 ] {0c7089d3-5280-4928-87ac-948f587ab873} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 982, line 984) (in query: SELECT parseDateTime32BestEffortOrNull();) 2025.06.13 15:44:32.810159 [ 5978 ] {97f78570-9664-4129-89c1-85feea1b56fd} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function isDecimalOverflow: In scope SELECT isDecimalOverflow(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 751, line 752) (in query: SELECT isDecimalOverflow(-1);) 2025.06.13 15:44:32.839043 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function isDecimalOverflow: In scope SELECT isDecimalOverflow(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:32.855927 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:32.937894 [ 8431 ] {527e6f93-fd17-476d-9c86-4ea94c36bad3} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 983, line 985) (in query: SELECT parseDateTime32BestEffortOrZero();) 2025.06.13 15:44:32.945872 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:32.947519 [ 5978 ] {2dfab16d-f2ed-4aa3-bdc9-9b9f6b9ed578} executeQuery: Code: 43. DB::Exception: First argument for function isDynamicElementInSharedData must be Dynamic, got Int8 instead: In scope SELECT isDynamicElementInSharedData(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 752, line 753) (in query: SELECT isDynamicElementInSharedData(-1);) 2025.06.13 15:44:32.966877 [ 3821 ] {66cdc373-cdda-4b2a-baf6-bb0960774644} 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.20286.altinityantalya (altinity build)) (from [::1]:52932) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001afa8288 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:44:32.971706 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function isDynamicElementInSharedData must be Dynamic, got Int8 instead: In scope SELECT isDynamicElementInSharedData(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:32.984494 [ 3821 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001afa8288 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:44:33.006220 [ 8431 ] {ecc95845-10cb-4562-8c11-d096ae4ea292} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 984, line 986) (in query: SELECT parseDateTime64();) 2025.06.13 15:44:33.035418 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:33.119281 [ 18377 ] {d0c0cf5c-a5de-446b-99df-84d183466ee2} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 2.31 MiB (attempt to allocate chunk of 1.72 MiB), maximum: 9.31 GiB: while executing 'FUNCTION intHash64(__table1.number :: 2) -> intHash64(__table1.number) UInt64 : 0'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53336) (comment: 00429_long_http_bufferization.sh) (query 1, line 1) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1500000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc3b14 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc3a71 11. COW::immutable_ptr DB::TargetSpecific::AVX2::FunctionIntHash::executeType(std::vector> const&) const @ 0x0000000017fba446 12. DB::TargetSpecific::AVX2::FunctionIntHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb8bf9 13. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb107e 14. DB::FunctionIntHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb3138 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 22. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 23. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:33.144557 [ 18377 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 2.31 MiB (attempt to allocate chunk of 1.72 MiB), maximum: 9.31 GiB: while executing 'FUNCTION intHash64(__table1.number :: 2) -> intHash64(__table1.number) UInt64 : 0'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc3b14 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc3a71 11. COW::immutable_ptr DB::TargetSpecific::AVX2::FunctionIntHash::executeType(std::vector> const&) const @ 0x0000000017fba446 12. DB::TargetSpecific::AVX2::FunctionIntHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb8bf9 13. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb107e 14. DB::FunctionIntHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017fb3138 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 22. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 23. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 31. ? @ 0x00007f2f4224dac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:44:33.272853 [ 8431 ] {35c22e4e-7f81-494f-97e9-b0ad96fc6046} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffort'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 985, line 987) (in query: SELECT parseDateTime64BestEffort();) 2025.06.13 15:44:33.280209 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffort'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:33.369933 [ 8431 ] {9c98c9dd-2611-4a5c-b59c-0044d28b7e44} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 986, line 988) (in query: SELECT parseDateTime64BestEffortOrNull();) 2025.06.13 15:44:33.390503 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:33.417034 [ 5978 ] {0472818f-7bc6-4430-aced-ab6f5b5d03dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 1, should be 2: In scope SELECT isIPAddressInRange(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 754, line 755) (in query: SELECT isIPAddressInRange(-1);) 2025.06.13 15:44:33.424254 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 1, should be 2: In scope SELECT isIPAddressInRange(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:33.512961 [ 8431 ] {e7867542-d1aa-42b3-93ec-24348cccb4a9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 987, line 989) (in query: SELECT parseDateTime64BestEffortOrZero();) 2025.06.13 15:44:33.518840 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:33.530606 [ 5978 ] {6a4d759d-4c28-4173-af1e-25f14ffa1538} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function isIPv4String: In scope SELECT isIPv4String(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 755, line 756) (in query: SELECT isIPv4String(-1);) 2025.06.13 15:44:33.544902 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function isIPv4String: In scope SELECT isIPv4String(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:33.578488 [ 8431 ] {26a0b180-72f0-41ec-abc0-139f5cd2ab3d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUS'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 988, line 990) (in query: SELECT parseDateTime64BestEffortUS();) 2025.06.13 15:44:33.588758 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUS'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:33.650399 [ 5978 ] {91af1c84-800f-45e7-8775-9d519cdf0a06} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function isIPv6String: In scope SELECT isIPv6String(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 756, line 757) (in query: SELECT isIPv6String(-1);) 2025.06.13 15:44:33.692868 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function isIPv6String: In scope SELECT isIPv6String(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:33.746807 [ 8431 ] {428e4099-3034-45c4-8f3d-51e9b0e94de6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUSOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUSOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 989, line 991) (in query: SELECT parseDateTime64BestEffortUSOrNull();) 2025.06.13 15:44:33.755361 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUSOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUSOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:33.891272 [ 8431 ] {446e881b-c864-44af-aae9-40b8a9c9dc62} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUSOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUSOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 990, line 992) (in query: SELECT parseDateTime64BestEffortUSOrZero();) 2025.06.13 15:44:33.896540 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUSOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUSOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:34.011783 [ 7755 ] {d4d19f32-b34c-4e89-a22b-3a694759f009} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43516) (comment: 01490_nullable_string_to_enum.sql) (query 3, line 4) (in query: CREATE TABLE t_enum(x Enum8('hello' = 1, 'world' = 2)) ENGINE = TinyLog;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:34.033670 [ 18510 ] {23ba5dd9-e71a-43ce-9133-e91d6c15503d} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43540) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:34.033938 [ 7755 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:34.052918 [ 18510 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:34.090097 [ 8431 ] {80940d16-f958-4f12-b9ab-264d8ffcaa5d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64InJodaSyntax'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64InJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 991, line 993) (in query: SELECT parseDateTime64InJodaSyntax();) 2025.06.13 15:44:34.101031 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64InJodaSyntax'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64InJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:34.159986 [ 8431 ] {67d5c8d4-9612-4c58-ad8b-4d46a49f1c7c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64InJodaSyntaxOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64InJodaSyntaxOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 992, line 994) (in query: SELECT parseDateTime64InJodaSyntaxOrNull();) 2025.06.13 15:44:34.187924 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64InJodaSyntaxOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64InJodaSyntaxOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:34.264661 [ 5978 ] {7e2fdcb1-d3ec-4b97-a263-f44705c21547} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 1, should be 2: In scope SELECT isNotDistinctFrom(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 759, line 760) (in query: SELECT isNotDistinctFrom(-1);) 2025.06.13 15:44:34.288432 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 1, should be 2: In scope SELECT isNotDistinctFrom(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:34.297393 [ 8431 ] {2622e2c1-0794-4f2b-8c90-fce0fcc28831} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64InJodaSyntaxOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64InJodaSyntaxOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 993, line 995) (in query: SELECT parseDateTime64InJodaSyntaxOrZero();) 2025.06.13 15:44:34.307594 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64InJodaSyntaxOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64InJodaSyntaxOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:34.430927 [ 8431 ] {6c198425-6537-48aa-97fb-43621f6f8b77} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64OrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 994, line 996) (in query: SELECT parseDateTime64OrNull();) 2025.06.13 15:44:34.442301 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64OrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:34.508757 [ 8431 ] {a42b356f-302e-419b-a973-073e9dd00ab7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64OrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 995, line 997) (in query: SELECT parseDateTime64OrZero();) 2025.06.13 15:44:34.519730 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64OrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:34.646616 [ 8431 ] {3c8bb73f-29a6-4237-8a5d-31ba72fb9cf5} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffort doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 996, line 998) (in query: SELECT parseDateTimeBestEffort();) 2025.06.13 15:44:34.690507 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffort doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:34.795537 [ 8431 ] {625853aa-0d2f-4803-a28e-7e2e1fc437e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 997, line 999) (in query: SELECT parseDateTimeBestEffortOrNull();) 2025.06.13 15:44:34.799053 [ 8101 ] {a6449188-0011-45f2-aa48-b697fab2fa7f} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43590) (comment: 02165_h3_exact_edge_length_m.sql) (query 2, line 5) (in query: CREATE TABLE h3_indexes (h3_index UInt64) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:34.813671 [ 8101 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:34.813767 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:34.878057 [ 5978 ] {0b92c588-c42d-4e42-80a5-bdd74210bf41} executeQuery: Code: 43. DB::Exception: The first argument of function isValidJSON should be a string containing JSON, illegal type: Int8: In scope SELECT isValidJSON(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 763, line 764) (in query: SELECT isValidJSON(-1);) 2025.06.13 15:44:34.889483 [ 8431 ] {b4e7d3e9-6c21-4085-aa3c-586ef769bdc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 998, line 1000) (in query: SELECT parseDateTimeBestEffortOrZero();) 2025.06.13 15:44:34.893929 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function isValidJSON should be a string containing JSON, illegal type: Int8: In scope SELECT isValidJSON(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:34.935960 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:35.013135 [ 8431 ] {3fb2fbde-676b-4b66-a004-d68a38c225ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUS doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 999, line 1001) (in query: SELECT parseDateTimeBestEffortUS();) 2025.06.13 15:44:35.014575 [ 5978 ] {7a609f5a-4080-4ec7-ab25-87c36b1c09fc} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function isValidUTF8: In scope SELECT isValidUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 764, line 765) (in query: SELECT isValidUTF8(-1);) 2025.06.13 15:44:35.022040 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUS doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:35.035946 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function isValidUTF8: In scope SELECT isValidUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:35.164032 [ 8431 ] {d52b75f1-2ac2-41bb-ad1f-9f29e470ab17} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1000, line 1002) (in query: SELECT parseDateTimeBestEffortUSOrNull();) 2025.06.13 15:44:35.169387 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:35.248235 [ 8431 ] {78a7355e-43ec-4788-9a90-09f8e8bc74ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1001, line 1003) (in query: SELECT parseDateTimeBestEffortUSOrZero();) 2025.06.13 15:44:35.265592 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:35.337804 [ 8431 ] {6f24eaeb-09fb-406f-9938-cf078b5b2d7a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntax'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1002, line 1004) (in query: SELECT parseDateTimeInJodaSyntax();) 2025.06.13 15:44:35.345986 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntax'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:35.360211 [ 5978 ] {3495ce73-10f0-4112-82c3-df0fff18ffc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 1, should be 2: In scope SELECT jaroSimilarity(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 766, line 767) (in query: SELECT jaroSimilarity(-1);) 2025.06.13 15:44:35.367914 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 1, should be 2: In scope SELECT jaroSimilarity(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:35.464634 [ 8431 ] {3fc2fac1-0029-4c5c-a163-b0fab058d1f9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntaxOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntaxOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1003, line 1005) (in query: SELECT parseDateTimeInJodaSyntaxOrNull();) 2025.06.13 15:44:35.479142 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntaxOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntaxOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:35.483294 [ 5978 ] {d42f2f33-bc1c-4e82-8267-bc15d385436b} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 1, should be 2: In scope SELECT jaroWinklerSimilarity(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 767, line 768) (in query: SELECT jaroWinklerSimilarity(-1);) 2025.06.13 15:44:35.490626 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 1, should be 2: In scope SELECT jaroWinklerSimilarity(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:35.583085 [ 8431 ] {dc0c5788-5837-4cc7-8e8d-9106894c438e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntaxOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntaxOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1004, line 1006) (in query: SELECT parseDateTimeInJodaSyntaxOrZero();) 2025.06.13 15:44:35.591620 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntaxOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntaxOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:35.615688 [ 8442 ] {4168d4f3-c057-44b9-bcfa-d0c78e8edc4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 2, should be 0: In scope SELECT yesterday(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1609, line 1612) (in query: SELECT yesterday(NULL, NULL);) 2025.06.13 15:44:35.627564 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 2, should be 0: In scope SELECT yesterday(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:35.688482 [ 8431 ] {3116d426-8348-4881-9477-8749a4a10ea5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1005, line 1007) (in query: SELECT parseDateTimeOrNull();) 2025.06.13 15:44:35.712686 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:35.715876 [ 5978 ] {dd11ac0b-08a0-407e-a892-32f9f554009a} executeQuery: Code: 36. DB::Exception: Arguments for javaHashUTF16LE must be in the form of UTF-16: In scope SELECT javaHashUTF16LE(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 769, line 770) (in query: SELECT javaHashUTF16LE(-1);) 2025.06.13 15:44:35.719361 [ 18602 ] {f3fc27c1-4dd0-4d79-be77-35cdf42eab15} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43640) (comment: 02785_date_predicate_optimizations_ast_query_tree_rewrite.sql) (query 2, line 2) (in query: CREATE TABLE date_t (`id` UInt32, `value1` String, `date1` Date) ENGINE = ReplacingMergeTree ORDER BY id SETTINGS index_granularity = 5798, min_bytes_for_wide_part = 515983366, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 450789843, compact_parts_max_bytes_to_buffer = 164266648, compact_parts_max_granules_to_buffer = 56, compact_parts_merge_max_bytes_to_prefetch_part = 28364853, merge_max_block_size = 16240, old_parts_lifetime = 410., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 91584, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 8887283, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 57, 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 = 69914, primary_key_compress_block_size = 23415, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:35.725051 [ 18602 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:35.727660 [ 8442 ] {62792da3-861b-4538-a7d1-6ab4f6c3a803} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 2, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49626) (comment: 00534_functions_bad_arguments8.sh) (query 1610, line 1613) (in query: SELECT zookeeperSessionUptime(NULL, NULL);) 2025.06.13 15:44:35.724062 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: Arguments for javaHashUTF16LE must be in the form of UTF-16: In scope SELECT javaHashUTF16LE(-1). (BAD_ARGUMENTS) 2025.06.13 15:44:35.764148 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 2, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:35.856946 [ 8431 ] {64a3cdf4-6406-4776-85f7-61bfaa96120a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1006, line 1008) (in query: SELECT parseDateTimeOrZero();) 2025.06.13 15:44:35.868485 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:35.869291 [ 5978 ] {d77ab579-092c-4ae2-952d-4df58e641bea} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 1, should be greater or equal to 3: In scope SELECT joinGet(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 770, line 771) (in query: SELECT joinGet(-1);) 2025.06.13 15:44:35.874160 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 1, should be greater or equal to 3: In scope SELECT joinGet(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:35.942406 [ 8431 ] {c391e63e-d492-416b-bdb6-29e3a7778ffb} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1007, line 1009) (in query: SELECT parseReadableSize();) 2025.06.13 15:44:35.947093 [ 8431 ] {} 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) 2025.06.13 15:44:35.954435 [ 5978 ] {e3640620-ef21-4f36-8733-22c621b9d802} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 1, should be greater or equal to 3: In scope SELECT joinGetOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 771, line 772) (in query: SELECT joinGetOrNull(-1);) 2025.06.13 15:44:35.969579 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 1, should be greater or equal to 3: In scope SELECT joinGetOrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:36.047714 [ 5978 ] {29f938ac-8348-41fd-a39e-393f0cf20e24} executeQuery: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT jsonMergePatch(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 772, line 773) (in query: SELECT jsonMergePatch(-1);) 2025.06.13 15:44:36.054076 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT jsonMergePatch(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:36.064852 [ 8431 ] {eecba705-423a-4f9a-9690-46dcc36133c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 0, should be 1: In scope SELECT parseReadableSizeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1008, line 1010) (in query: SELECT parseReadableSizeOrNull();) 2025.06.13 15:44:36.098756 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 0, should be 1: In scope SELECT parseReadableSizeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:36.174082 [ 8431 ] {ec4190ea-3b49-41c3-a78f-b17af2e6dfbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 0, should be 1: In scope SELECT parseReadableSizeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1009, line 1011) (in query: SELECT parseReadableSizeOrZero();) 2025.06.13 15:44:36.184432 [ 5978 ] {cedaf6a5-f643-4196-840e-07e3d2027fde} executeQuery: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 1, should be 2: In scope SELECT jumpConsistentHash(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 773, line 774) (in query: SELECT jumpConsistentHash(-1);) 2025.06.13 15:44:36.193106 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 0, should be 1: In scope SELECT parseReadableSizeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:36.198683 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 1, should be 2: In scope SELECT jumpConsistentHash(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:36.267076 [ 8431 ] {07b81a85-6e4b-4fa8-8557-14f203468274} executeQuery: Code: 35. DB::Exception: Number of arguments for function parseTimeDelta doesn't match: passed 0, should be 1.: In scope SELECT parseTimeDelta(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1010, line 1012) (in query: SELECT parseTimeDelta();) 2025.06.13 15:44:36.279444 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function parseTimeDelta doesn't match: passed 0, should be 1.: In scope SELECT parseTimeDelta(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:36.386557 [ 8431 ] {09fd4f17-ca96-4c2a-a3a0-e41f668d16ea} executeQuery: Code: 42. DB::Exception: Function partitionId requires at least one argument.: In scope SELECT partitionID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1011, line 1013) (in query: SELECT partitionID();) 2025.06.13 15:44:36.400888 [ 5978 ] {9c6a3339-84da-4b82-811b-096236938296} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function keccak256: In scope SELECT keccak256(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 775, line 776) (in query: SELECT keccak256(-1);) 2025.06.13 15:44:36.402440 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function partitionId requires at least one argument.: In scope SELECT partitionID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:36.405792 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function keccak256: In scope SELECT keccak256(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:36.461903 [ 4107 ] {221fa56e-8e9a-4936-9aa5-6550d6ac5de2} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43724) (comment: 02097_remove_sample_by.sql) (query 2, line 5) (in query: CREATE TABLE t_remove_sample_by(id UInt64) ENGINE = MergeTree ORDER BY id SAMPLE BY id;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:36.476430 [ 4107 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:36.639303 [ 9642 ] {d3a9a21e-5bdd-46c9-80f0-18df6f1cd1f4} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43744) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:36.656482 [ 9642 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:36.686170 [ 8431 ] {6bdee2bd-2570-4658-965b-e00cd753eb22} executeQuery: Code: 42. DB::Exception: Function partitionId requires at least one argument.: In scope SELECT partitionId(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1012, line 1014) (in query: SELECT partitionId();) 2025.06.13 15:44:36.716827 [ 5978 ] {4cf5d0c5-09c8-4aad-84c1-8bf07fa561e1} executeQuery: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 776, line 777) (in query: SELECT kolmogorovSmirnovTest(-1);) 2025.06.13 15:44:36.717002 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function partitionId requires at least one argument.: In scope SELECT partitionId(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:36.730161 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:36.797194 [ 8431 ] {ab3279c5-7e29-40e7-abfe-deb4532284cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 0, should be 1: In scope SELECT path(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1013, line 1015) (in query: SELECT path();) 2025.06.13 15:44:36.804820 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 0, should be 1: In scope SELECT path(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:36.823297 [ 5978 ] {567ba965-5c86-4370-9012-42218fb11e1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 1, should be 2: In scope SELECT kostikConsistentHash(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 777, line 778) (in query: SELECT kostikConsistentHash(-1);) 2025.06.13 15:44:36.835403 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 1, should be 2: In scope SELECT kostikConsistentHash(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:36.881393 [ 4107 ] {9fd10669-a120-4b31-bfe8-aa41938e84e0} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43762) (comment: 02243_arrow_read_null_type_to_nullable_column.sh) (query 1, line 1) (in query: create table test_02243 (image_path Nullable(String), caption Nullable(String), NSFW Nullable(String), similarity Nullable(Float64), LICENSE Nullable(String), url Nullable(String), key Nullable(UInt64), shard_id Nullable(UInt64), status Nullable(String), error_message Nullable(String), width Nullable(UInt32), height Nullable(UInt32), exif Nullable(String), original_width Nullable(UInt32), original_height Nullable(UInt32)) engine=Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:44:36.915168 [ 4107 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:44:36.965215 [ 5978 ] {54c2504d-0e48-40bb-95c2-46e99f895785} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument (condition) of function if. Must be UInt8.: In scope SELECT kql_array_sort_asc(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 778, line 779) (in query: SELECT kql_array_sort_asc(-1);) 2025.06.13 15:44:36.971405 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument (condition) of function if. Must be UInt8.: In scope SELECT kql_array_sort_asc(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:36.983270 [ 8431 ] {8c94d7a2-7f2f-4972-bb03-00dbbffefd01} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 0, should be 1: In scope SELECT pathFull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1014, line 1016) (in query: SELECT pathFull();) 2025.06.13 15:44:37.010156 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 0, should be 1: In scope SELECT pathFull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:37.136364 [ 5978 ] {10e4f430-020c-4a6a-8ece-c030bcb043bb} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument (condition) of function if. Must be UInt8.: In scope SELECT kql_array_sort_desc(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 779, line 780) (in query: SELECT kql_array_sort_desc(-1);) 2025.06.13 15:44:37.150786 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument (condition) of function if. Must be UInt8.: In scope SELECT kql_array_sort_desc(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:37.189257 [ 8431 ] {cb39dd2a-231c-4b5d-9419-6232c373907d} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1015, line 1017) (in query: SELECT percentRank();) 2025.06.13 15:44:37.194261 [ 8431 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:44:37.282841 [ 8431 ] {d1d30957-e3ef-4979-9c55-9090c4aaa4af} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1016, line 1018) (in query: SELECT percent_rank();) 2025.06.13 15:44:37.301344 [ 8431 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:44:37.349463 [ 18511 ] {efed29b4-6989-413d-a0c3-b2e4685c3f8a} executeQuery: Code: 60. DB::Exception: Table test_7.test_02243 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43832) (comment: 02243_arrow_read_null_type_to_nullable_column.sh) (query 1, line 1) (in query: insert into test_02243 format Parquet), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:37.357937 [ 18511 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.test_02243 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:37.515270 [ 8431 ] {718129e5-109c-4e0d-b718-37c1f6cf7a09} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT plus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1018, line 1020) (in query: SELECT plus();) 2025.06.13 15:44:37.522130 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT plus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:37.631267 [ 8431 ] {434e52b0-3b17-43a7-963e-f988de7954b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT pmod(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1019, line 1021) (in query: SELECT pmod();) 2025.06.13 15:44:37.640208 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT pmod(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:37.684302 [ 3894 ] {5ff52bd2-6e02-4177-b921-3e2de8aa0220} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43490) (comment: 01710_projections_order_by_incomplete.sql) (query 10, line 15) (in query: select t from data_proj_order_by_incomp where t > 0 order by t settings max_threads=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:44:37.708154 [ 3894 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:44:37.731177 [ 8431 ] {f730d142-0adf-4f74-961b-cdcb54eeb638} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1020, line 1022) (in query: SELECT pointInEllipses();) 2025.06.13 15:44:37.738074 [ 5978 ] {3edc9214-ef1a-41a4-82aa-c581760da63a} executeQuery: Code: 36. DB::Exception: The function 'lagInFrame' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 782, line 783) (in query: SELECT lagInFrame(-1);) 2025.06.13 15:44:37.741492 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:37.751330 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: The function 'lagInFrame' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:44:37.805319 [ 4172 ] {500bff2c-95db-4b39-9261-2a71b120df4f} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43778) (comment: 00571_non_exist_database_when_create_materializ_view.sql) (query 6, line 8) (in query: CREATE TABLE test_00571 ( date Date, platform Enum8('a' = 0, 'b' = 1, 'c' = 2), app Enum8('a' = 0, 'b' = 1) ) ENGINE = MergeTree(date, (platform, app), 8192);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:37.817953 [ 4172 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:37.839030 [ 8431 ] {86e04417-b7dd-4a1c-b611-3b482d242db2} executeQuery: Code: 35. DB::Exception: Function pointInPolygon requires at least 2 arguments: In scope SELECT pointInPolygon(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1021, line 1023) (in query: SELECT pointInPolygon();) 2025.06.13 15:44:37.842883 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function pointInPolygon requires at least 2 arguments: In scope SELECT pointInPolygon(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:37.943140 [ 9644 ] {6be613ed-7598-45ad-981a-5cd70c81c2e4} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_02243' in scope SELECT count() FROM test_02243. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43842) (comment: 02243_arrow_read_null_type_to_nullable_column.sh) (query 1, line 1) (in query: select count() from test_02243), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:44:37.943909 [ 5978 ] {1f4c920c-3261-45c9-8352-d4f513654c4a} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 783, line 784) (in query: SELECT largestTriangleThreeBuckets(-1);) 2025.06.13 15:44:37.952768 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:37.968583 [ 9644 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_02243' in scope SELECT count() FROM test_02243. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:44:38.000231 [ 8431 ] {b78fb3a4-ab72-4c5a-8a62-8325b49fa326} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonAreaCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1022, line 1024) (in query: SELECT polygonAreaCartesian();) 2025.06.13 15:44:38.026958 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonAreaCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:38.156419 [ 8431 ] {c5ff09d5-c37e-46f7-8488-d913b8965a7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 0, should be 1: In scope SELECT polygonAreaSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1023, line 1025) (in query: SELECT polygonAreaSpherical();) 2025.06.13 15:44:38.176612 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 0, should be 1: In scope SELECT polygonAreaSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:38.246008 [ 8431 ] {ddc6c016-5c92-42ed-8bfd-0e55e1a8cb13} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonConvexHullCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1024, line 1026) (in query: SELECT polygonConvexHullCartesian();) 2025.06.13 15:44:38.250176 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonConvexHullCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:38.328786 [ 3931 ] {a89c94f4-d1ea-45f5-a4e5-3b0952d31f06} executeQuery: Code: 57. DB::Exception: Table test_xp2trv6j.codecTest already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43550) (comment: 02313_test_fpc_codec.sql) (query 13, line 65) (in query: CREATE TABLE codecTest (`key` UInt64, `name` String, `ref_valueF64` Float64, `ref_valueF32` Float32, `valueF64` Float64 CODEC(FPC(4)), `valueF32` Float32 CODEC(FPC(4))) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 46415, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.4563232660293579, 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 = 462859480, compact_parts_max_granules_to_buffer = 82, compact_parts_merge_max_bytes_to_prefetch_part = 15442535, merge_max_block_size = 5121, old_parts_lifetime = 159., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 29487880, 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 = true, marks_compress_block_size = 42898, primary_key_compress_block_size = 75332, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:38.329401 [ 8431 ] {f641bb83-9004-46fb-97c9-6d06821b3dd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonPerimeterCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1025, line 1027) (in query: SELECT polygonPerimeterCartesian();) 2025.06.13 15:44:38.361076 [ 3931 ] {} TCPHandler: Code: 57. DB::Exception: Table test_xp2trv6j.codecTest already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:38.370984 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonPerimeterCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:38.452611 [ 8431 ] {a8c1bd4e-4567-40d9-aeba-c821cacbec3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 0, should be 1: In scope SELECT polygonPerimeterSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1026, line 1028) (in query: SELECT polygonPerimeterSpherical();) 2025.06.13 15:44:38.462951 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 0, should be 1: In scope SELECT polygonPerimeterSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:38.488611 [ 5005 ] {ea725836-b955-4f66-aa07-83747cc17a4d} executeQuery: Code: 60. DB::Exception: Table test_7.test_02243 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43868) (comment: 02243_arrow_read_null_type_to_nullable_column.sh) (query 1, line 1) (in query: drop table test_02243), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:44:38.511614 [ 5005 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.test_02243 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:44:38.514947 [ 5163 ] {8acb7b56-a5f8-43b8-82bb-cd655fd952e1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33766) (comment: 02313_test_fpc_codec.sql) (in query: DROP DATABASE IF EXISTS test_xp2trv6j SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:44:38.523833 [ 5163 ] {8acb7b56-a5f8-43b8-82bb-cd655fd952e1} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:38.573549 [ 8431 ] {0564df26-c495-4b25-951c-cce2613c5fe5} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsDistanceCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1027, line 1029) (in query: SELECT polygonsDistanceCartesian();) 2025.06.13 15:44:38.594151 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsDistanceCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:38.731826 [ 8431 ] {36760ee9-f870-4712-86ba-be40f528d474} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsDistanceSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1028, line 1030) (in query: SELECT polygonsDistanceSpherical();) 2025.06.13 15:44:38.752991 [ 5978 ] {a1a015a3-5108-4401-abb2-a6b1727ecd42} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function lower: In scope SELECT lcase(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 787, line 788) (in query: SELECT lcase(-1);) 2025.06.13 15:44:38.758285 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsDistanceSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:38.776861 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function lower: In scope SELECT lcase(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:38.869585 [ 5978 ] {0c0200cc-c992-483d-9952-5e6960559eb7} executeQuery: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 1, should be 2: In scope SELECT lcm(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 788, line 789) (in query: SELECT lcm(-1);) 2025.06.13 15:44:38.883223 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 1, should be 2: In scope SELECT lcm(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:38.905019 [ 8431 ] {bf53dcf4-910e-4142-bc8a-b8422e6bbb4d} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsEqualsCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1029, line 1031) (in query: SELECT polygonsEqualsCartesian();) 2025.06.13 15:44:38.918528 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsEqualsCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:39.006858 [ 8431 ] {d5088bd1-12dd-40ea-b543-5c0a564b94d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsIntersectionCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1030, line 1032) (in query: SELECT polygonsIntersectionCartesian();) 2025.06.13 15:44:39.024689 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsIntersectionCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:39.035987 [ 5978 ] {57728621-8be9-4815-a4f6-1b2a89030b03} executeQuery: Code: 36. DB::Exception: The function 'leadInFrame' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 789, line 790) (in query: SELECT leadInFrame(-1);) 2025.06.13 15:44:39.064298 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: The function 'leadInFrame' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:44:39.175970 [ 8431 ] {85559a99-6006-4332-bc95-12a640250dca} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsIntersectionSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1031, line 1033) (in query: SELECT polygonsIntersectionSpherical();) 2025.06.13 15:44:39.186965 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsIntersectionSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:39.224376 [ 6234 ] {7adc66ab-059f-41a3-baf3-2d6d5c6aa290} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43892) (comment: 02167_columns_with_dots_default_values.sql) (query 2, line 3) (in query: CREATE TABLE test_nested_default (`id` String, `with_dot.str` String, `with_dot.array` Array(String)) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 50130, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.006248242221772671, 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 = 5358981, compact_parts_max_granules_to_buffer = 71, compact_parts_merge_max_bytes_to_prefetch_part = 17419571, merge_max_block_size = 13345, old_parts_lifetime = 461., prefer_fetch_merged_part_size_threshold = 7412251647, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 534855033, index_granularity_bytes = 436986, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 18714, primary_key_compress_block_size = 67145, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:44:39.253694 [ 6234 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:44:39.307922 [ 8431 ] {8a5a270f-eb18-42b6-ac73-dc106dede172} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsSymDifferenceCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1032, line 1034) (in query: SELECT polygonsSymDifferenceCartesian();) 2025.06.13 15:44:39.335231 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsSymDifferenceCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:39.345083 [ 5978 ] {e82c334e-ef6a-4953-881b-25039ed0fbab} executeQuery: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 1, should be 2: In scope SELECT left(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 791, line 792) (in query: SELECT left(-1);) 2025.06.13 15:44:39.351037 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 1, should be 2: In scope SELECT left(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:39.421232 [ 8431 ] {fa250ffd-7baf-4928-89ca-b1d9af6bff02} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsSymDifferenceSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1033, line 1035) (in query: SELECT polygonsSymDifferenceSpherical();) 2025.06.13 15:44:39.426957 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsSymDifferenceSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:39.483209 [ 5978 ] {b833ec8c-f33c-4353-802a-69b863efe7b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 1, should be 2 or 3: In scope SELECT leftPad(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 792, line 793) (in query: SELECT leftPad(-1);) 2025.06.13 15:44:39.488516 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 1, should be 2 or 3: In scope SELECT leftPad(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:39.496788 [ 8101 ] {73492527-3289-47e9-8a1d-10a728a6e1e5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43754) (comment: 02243_make_date32_mysql.sql) (query 14, line 16) (in query: select makeDate32(cast(1980 as Date), 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:39.519293 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:39.546701 [ 8431 ] {0b2b26af-85ef-44ea-bc5c-9e68ae97a7d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsUnionCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1034, line 1036) (in query: SELECT polygonsUnionCartesian();) 2025.06.13 15:44:39.586294 [ 5978 ] {6b421567-6fe4-470b-91f7-ac99fc686f4d} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPadUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT leftPadUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 793, line 794) (in query: SELECT leftPadUTF8(-1);) 2025.06.13 15:44:39.612779 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPadUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT leftPadUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:39.614774 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsUnionCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:39.660449 [ 8101 ] {00dc77f8-9e94-4dba-a552-842646a2165a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(-1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43754) (comment: 02243_make_date32_mysql.sql) (query 15, line 17) (in query: select makeDate32(cast(-1980 as Date), 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:39.696276 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(-1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:39.697373 [ 5005 ] {38bbb49c-c8e5-4e3a-97b1-3533be283c53::all_21_22_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:39.699294 [ 8431 ] {970c59c1-829e-4a47-853f-a0d462bfb041} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsUnionSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1035, line 1037) (in query: SELECT polygonsUnionSpherical();) 2025.06.13 15:44:39.708203 [ 5005 ] {7c009349-2de4-454b-a901-4e0bad4fbd0f} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43908) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:44:39.712063 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsUnionSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:39.727051 [ 5978 ] {70df3867-c768-4107-b490-f666a63dc971} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 1, should be 2: In scope SELECT leftUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 794, line 795) (in query: SELECT leftUTF8(-1);) 2025.06.13 15:44:39.733131 [ 5005 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:44:39.749447 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 1, should be 2: In scope SELECT leftUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:39.759218 [ 8101 ] {6921164b-9ca8-4de3-9e61-6ac222caf5f4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43754) (comment: 02243_make_date32_mysql.sql) (query 16, line 18) (in query: select makeDate32(cast(1980 as Date32), 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:39.769009 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:39.837928 [ 8431 ] {eee594b5-dba1-41ee-ac33-edaefb297cc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsWithinCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1036, line 1038) (in query: SELECT polygonsWithinCartesian();) 2025.06.13 15:44:39.846547 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsWithinCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:39.876782 [ 8101 ] {6d081718-a0a8-4b05-9077-cb763bd593df} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(-1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43754) (comment: 02243_make_date32_mysql.sql) (query 17, line 19) (in query: select makeDate32(cast(-1980 as Date32), 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:39.888966 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(-1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.007756 [ 8431 ] {b656c4cb-3251-43f1-9039-4d3a156db67b} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsWithinSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1037, line 1039) (in query: SELECT polygonsWithinSpherical();) 2025.06.13 15:44:40.008177 [ 5978 ] {66985f8d-f576-4498-837e-295ca1122fad} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 795, line 796) (in query: SELECT lemmatize(-1);) 2025.06.13 15:44:40.015849 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsWithinSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:40.022290 [ 5978 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:44:40.080944 [ 8101 ] {65884b55-e8df-42b2-b848-4cde00ed4dcd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43754) (comment: 02243_make_date32_mysql.sql) (query 18, line 20) (in query: select makeDate32(cast(1980 as DateTime), 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.089197 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.112568 [ 5978 ] {16f65f9a-645a-4c5e-a5af-8cb61241197b} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function length: In scope SELECT length(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 796, line 797) (in query: SELECT length(-1);) 2025.06.13 15:44:40.117444 [ 8431 ] {eda7e8fa-bb54-4efe-a04d-eefa240d6268} executeQuery: Code: 42. DB::Exception: Number of arguments for function port doesn't match: passed 0, should be 1 or 2: In scope SELECT port(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1038, line 1040) (in query: SELECT port();) 2025.06.13 15:44:40.118851 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function length: In scope SELECT length(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:40.125222 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function port doesn't match: passed 0, should be 1 or 2: In scope SELECT port(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:40.157348 [ 8101 ] {ed284414-429d-46b5-8767-ec66bc552778} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(-1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43754) (comment: 02243_make_date32_mysql.sql) (query 19, line 21) (in query: select makeDate32(cast(-1980 as DateTime), 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.179457 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(-1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.219264 [ 5978 ] {f180a07d-1499-4021-8ee7-851ce0ede449} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function lengthUTF8: In scope SELECT lengthUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 797, line 798) (in query: SELECT lengthUTF8(-1);) 2025.06.13 15:44:40.221594 [ 8431 ] {8b0bf0ee-cf08-41ad-a5f8-babf2394e699} executeQuery: Code: 42. DB::Exception: Number of arguments for function portRFC doesn't match: passed 0, should be 1 or 2: In scope SELECT portRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1039, line 1041) (in query: SELECT portRFC();) 2025.06.13 15:44:40.233839 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function lengthUTF8: In scope SELECT lengthUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:40.241241 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function portRFC doesn't match: passed 0, should be 1 or 2: In scope SELECT portRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:40.366100 [ 8101 ] {7fb25172-b15c-447a-91a8-0d9ef0e60f5b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43754) (comment: 02243_make_date32_mysql.sql) (query 20, line 22) (in query: select makeDate32(cast(1980 as DateTime64), 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.375507 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.377807 [ 8431 ] {6546fac1-45b6-4e94-9094-ae00a6343e35} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT positionCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1040, line 1043) (in query: SELECT positionCaseInsensitive();) 2025.06.13 15:44:40.393021 [ 5978 ] {7ed92acd-0b50-4b8e-a726-74bf120b4aa3} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 1, should be 2: In scope SELECT less(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 798, line 799) (in query: SELECT less(-1);) 2025.06.13 15:44:40.393735 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT positionCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:40.430770 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 1, should be 2: In scope SELECT less(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:40.502946 [ 8101 ] {d0ae0326-0849-4610-bb35-d6b427df85df} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(-1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43754) (comment: 02243_make_date32_mysql.sql) (query 21, line 23) (in query: select makeDate32(cast(-1980 as DateTime64), 10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.511081 [ 8431 ] {222a9d2d-0ceb-4ed8-96a0-a767b2f5f7ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitiveUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT positionCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1041, line 1044) (in query: SELECT positionCaseInsensitiveUTF8();) 2025.06.13 15:44:40.511706 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(-1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.536319 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitiveUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT positionCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:40.572535 [ 18380 ] {67320245-88eb-42e4-8717-3cf1208d7994} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43962) (comment: 01040_dictionary_invalidate_query_switchover_long.sh) (query 1, line 2) (in query: CREATE TABLE dict_invalidate ENGINE = Memory AS SELECT 122 as dummy, toDateTime('2019-10-29 18:51:35') AS last_time FROM system.one), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:40.586159 [ 18380 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:40.637953 [ 8101 ] {e6794c3b-9e86-4cef-ae97-3be9c1a8d900} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('1980', '10'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43754) (comment: 02243_make_date32_mysql.sql) (query 22, line 24) (in query: select makeDate32('1980', '10');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.652005 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('1980', '10'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.652206 [ 8431 ] {7e4db849-3f44-4e20-ae80-a33d58782312} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT positionUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1042, line 1045) (in query: SELECT positionUTF8();) 2025.06.13 15:44:40.669427 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT positionUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:40.700161 [ 5978 ] {3302ca9e-6a10-42ee-ba40-fd4cf4a61d6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 1, should be 2: In scope SELECT lessOrEquals(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 799, line 800) (in query: SELECT lessOrEquals(-1);) 2025.06.13 15:44:40.705515 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 1, should be 2: In scope SELECT lessOrEquals(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:40.765326 [ 8101 ] {fc000e61-0c5e-47e1-ade1-ef6f550b8261} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('-1980', 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43754) (comment: 02243_make_date32_mysql.sql) (query 23, line 25) (in query: select makeDate32('-1980', 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.767945 [ 8431 ] {23034e05-7763-433d-9d4f-2f5c578ee169} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT positiveModulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1043, line 1046) (in query: SELECT positiveModulo();) 2025.06.13 15:44:40.775327 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('-1980', 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.789936 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT positiveModulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:40.796170 [ 5978 ] {5a39b9a7-1b53-4d0b-aa4c-19d0d59ad81b} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 1, should be 2: In scope SELECT levenshteinDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 800, line 801) (in query: SELECT levenshteinDistance(-1);) 2025.06.13 15:44:40.819036 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 1, should be 2: In scope SELECT levenshteinDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:40.852546 [ 8101 ] {472089a9-206f-4080-8451-3b6686ece822} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('aa', 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43754) (comment: 02243_make_date32_mysql.sql) (query 24, line 26) (in query: select makeDate32('aa', 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.856421 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('aa', 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.912237 [ 8431 ] {89b9f112-a1f1-4e77-918f-fae988ab7665} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT positive_modulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1044, line 1047) (in query: SELECT positive_modulo();) 2025.06.13 15:44:40.924501 [ 5978 ] {16df330d-fa5a-488e-8ac3-948dec0736fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 1, should be 2: In scope SELECT levenshteinDistanceUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 801, line 802) (in query: SELECT levenshteinDistanceUTF8(-1);) 2025.06.13 15:44:40.928049 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT positive_modulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:40.957203 [ 8101 ] {4d3025dc-7cde-4078-9acd-9c9841982889} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'dayofyear' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32(1994, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43754) (comment: 02243_make_date32_mysql.sql) (query 25, line 27) (in query: select makeDate32(1994, 'aa');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:40.979647 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 1, should be 2: In scope SELECT levenshteinDistanceUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:40.990291 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'dayofyear' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32(1994, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001dcc5d8e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:41.052644 [ 8431 ] {55131220-db58-4260-87df-a2b3d7056bf1} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 0, should be 2: In scope SELECT pow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1045, line 1048) (in query: SELECT pow();) 2025.06.13 15:44:41.064824 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 0, should be 2: In scope SELECT pow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:41.154372 [ 8431 ] {86119c81-3f6b-48ca-8d79-74bdc90da8dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 0, should be 2: In scope SELECT power(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1046, line 1049) (in query: SELECT power();) 2025.06.13 15:44:41.167946 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 0, should be 2: In scope SELECT power(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:41.211404 [ 5978 ] {b81e3c0f-a615-42f3-959c-9e9314e6d745} executeQuery: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 1, should be 2: In scope SELECT like(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 803, line 804) (in query: SELECT like(-1);) 2025.06.13 15:44:41.224704 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 1, should be 2: In scope SELECT like(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:41.249419 [ 18380 ] {1c268d82-47c1-46fa-893c-48699c67a7f4} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44022) (comment: 01040_dictionary_invalidate_query_switchover_long.sh) (query 1, line 2) (in query: CREATE DICTIONARY invalidate ( dummy UInt64, two UInt8 EXPRESSION dummy ) PRIMARY KEY dummy SOURCE(CLICKHOUSE(HOST 'localhost' PORT tcpPort() USER 'default' TABLE 'dict_invalidate' DB currentDatabase() INVALIDATE_QUERY 'select max(last_time) from dict_invalidate')) LIFETIME(MIN 0 MAX 1) LAYOUT(FLAT())), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:41.263356 [ 8431 ] {a4e353fe-d4b5-4134-8c18-d533cc0eb921} executeQuery: Code: 42. DB::Exception: Number of arguments for function printf doesn't match: passed 0, should be at least 1: In scope SELECT printf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1047, line 1050) (in query: SELECT printf();) 2025.06.13 15:44:41.328593 [ 18380 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:41.328659 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function printf doesn't match: passed 0, should be at least 1: In scope SELECT printf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:41.399060 [ 8431 ] {0bc87b18-41bc-48d7-88ca-77f7829c934d} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 0, should be 6: In scope SELECT proportionsZTest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1048, line 1051) (in query: SELECT proportionsZTest();) 2025.06.13 15:44:41.424195 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 0, should be 6: In scope SELECT proportionsZTest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:41.525620 [ 5978 ] {b34b5cb4-1bc2-42d1-9363-caf9b5eec170} executeQuery: Code: 42. DB::Exception: Number of arguments for function locate doesn't match: passed 1, should be 2 or 3: In scope SELECT locate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 805, line 806) (in query: SELECT locate(-1);) 2025.06.13 15:44:41.531952 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function locate doesn't match: passed 1, should be 2 or 3: In scope SELECT locate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:41.548204 [ 8431 ] {85fb5662-8271-4aa7-8384-5b8cc0a4eccc} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 0, should be 1: In scope SELECT protocol(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1049, line 1052) (in query: SELECT protocol();) 2025.06.13 15:44:41.559195 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 0, should be 1: In scope SELECT protocol(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:41.778960 [ 8431 ] {2a0f5c9c-43eb-4ca0-b10a-4c6f05617818} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1050, line 1053) (in query: SELECT punycodeDecode();) 2025.06.13 15:44:41.836762 [ 8431 ] {} 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) 2025.06.13 15:44:41.889214 [ 8431 ] {2d729e2a-6075-4200-8fb8-8d44dfc6824e} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1051, line 1054) (in query: SELECT punycodeEncode();) 2025.06.13 15:44:41.904565 [ 8431 ] {} 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) 2025.06.13 15:44:42.002432 [ 8431 ] {51430c84-ef74-4ec3-a6fa-b70362fbd7f2} executeQuery: Code: 35. DB::Exception: Aggregate function quantile requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1052, line 1055) (in query: SELECT quantile();) 2025.06.13 15:44:42.014282 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantile requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:42.072811 [ 8431 ] {2c582933-9933-499b-aaac-c854a26102a2} executeQuery: Code: 42. DB::Exception: Aggregate function quantileBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1053, line 1056) (in query: SELECT quantileBFloat16();) 2025.06.13 15:44:42.077151 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:42.162557 [ 8431 ] {57f44ac9-acb6-459d-a233-b8067cdca0d8} executeQuery: Code: 35. DB::Exception: Aggregate function quantileBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1054, line 1057) (in query: SELECT quantileBFloat16Weighted();) 2025.06.13 15:44:42.169687 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:42.217418 [ 9636 ] {f414fffa-4145-4803-b7b4-0b6714320878} executeQuery: Code: 36. DB::Exception: Dictionary (`invalidate`) not found: In scope SELECT dictGetUInt8('invalidate', 'two', toUInt64(122)). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44056) (comment: 01040_dictionary_invalidate_query_switchover_long.sh) (query 1, line 1) (in query: SELECT dictGetUInt8('invalidate', 'two', toUInt64(122))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x000000002dbe2855 6. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x000000002dbe314f 7. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x0000000017f4c186 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017f4576a 9. DB::FunctionDictGetImpl, DB::NameDictGetUInt8, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f616a7 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:44:42.237249 [ 9636 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`invalidate`) not found: In scope SELECT dictGetUInt8('invalidate', 'two', toUInt64(122)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x000000002dbe2855 6. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x000000002dbe314f 7. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x0000000017f4c186 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017f4576a 9. DB::FunctionDictGetImpl, DB::NameDictGetUInt8, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f616a7 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:44:42.247633 [ 5978 ] {8b456bd9-4acb-4aa2-8928-03178d1918cb} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function logTrace: In scope SELECT logTrace(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 810, line 811) (in query: SELECT logTrace(-1);) 2025.06.13 15:44:42.254145 [ 8431 ] {a5fe1d01-696e-468b-b93e-c867427e6cde} executeQuery: Code: 35. DB::Exception: Aggregate function quantileDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1055, line 1058) (in query: SELECT quantileDD();) 2025.06.13 15:44:42.259719 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function logTrace: In scope SELECT logTrace(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:42.265905 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:42.369456 [ 5978 ] {6c482934-712c-4159-9b36-973a34dd5572} executeQuery: Code: 43. DB::Exception: First first argument of function lowCardinalityIndexes must be ColumnLowCardinality, but got Int8: In scope SELECT lowCardinalityIndices(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 811, line 812) (in query: SELECT lowCardinalityIndices(-1);) 2025.06.13 15:44:42.385295 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First first argument of function lowCardinalityIndexes must be ColumnLowCardinality, but got Int8: In scope SELECT lowCardinalityIndices(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:42.390135 [ 8431 ] {9605804b-76a0-4d19-8fe3-7166317e0fad} executeQuery: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1056, line 1059) (in query: SELECT quantileDeterministic();) 2025.06.13 15:44:42.400236 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:42.508685 [ 5978 ] {92889aa9-1d67-4b1d-9155-fd8a7e433320} executeQuery: Code: 43. DB::Exception: First first argument of function lowCardinalityKeys must be ColumnLowCardinality, but got Int8: In scope SELECT lowCardinalityKeys(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 812, line 813) (in query: SELECT lowCardinalityKeys(-1);) 2025.06.13 15:44:42.513542 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First first argument of function lowCardinalityKeys must be ColumnLowCardinality, but got Int8: In scope SELECT lowCardinalityKeys(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:42.522853 [ 8431 ] {69d3d25d-6498-404e-87da-ea80de780411} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1057, line 1060) (in query: SELECT quantileExact();) 2025.06.13 15:44:42.541699 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:42.620763 [ 5978 ] {44095eea-e9ea-4e08-8f6b-1c665becdfd2} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function lower: In scope SELECT lower(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 813, line 814) (in query: SELECT lower(-1);) 2025.06.13 15:44:42.641213 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function lower: In scope SELECT lower(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:42.656629 [ 8431 ] {cbe368de-fd07-4505-9377-ac6ffb64f210} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactExclusive requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1058, line 1061) (in query: SELECT quantileExactExclusive();) 2025.06.13 15:44:42.665825 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactExclusive requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:42.716645 [ 5163 ] {b068b02b-b6d6-4b25-b327-cbb04fd2fa2e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=877, jobs=837). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44044) (comment: 02341_analyzer_aliases_basics.sql) (query 5, line 8) (in query: WITH 1 as a SELECT a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:42.724482 [ 5163 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=877, jobs=837). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:44:42.812940 [ 5978 ] {576bd3b2-e012-4708-96f3-1bc6c0813747} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function lowerUTF8: In scope SELECT lowerUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 814, line 815) (in query: SELECT lowerUTF8(-1);) 2025.06.13 15:44:42.817375 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function lowerUTF8: In scope SELECT lowerUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:42.827613 [ 8431 ] {b3b6df88-b93d-473b-ace2-c2c2fac85951} executeQuery: Code: 35. DB::Exception: Aggregate function quantileExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1059, line 1062) (in query: SELECT quantileExactHigh();) 2025.06.13 15:44:42.838735 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:42.913700 [ 5978 ] {98cf983a-514c-4b9b-908a-ac0300bdb79b} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 1, should be 2 or 3: In scope SELECT lpad(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 815, line 816) (in query: SELECT lpad(-1);) 2025.06.13 15:44:42.922511 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 1, should be 2 or 3: In scope SELECT lpad(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:42.952792 [ 8431 ] {2e9aa685-7479-4d91-87a3-8ff64b58352f} executeQuery: Code: 35. DB::Exception: Aggregate function quantileExactInclusive requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1060, line 1063) (in query: SELECT quantileExactInclusive();) 2025.06.13 15:44:42.964554 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileExactInclusive requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:43.131649 [ 5978 ] {df91bfd1-f2ee-48bf-b5f3-3705f1f748bd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimLeft'. Expected: String, got: Int8: In scope SELECT trimLeft(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 816, line 817) (in query: SELECT ltrim(-1);) 2025.06.13 15:44:43.138478 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimLeft'. Expected: String, got: Int8: In scope SELECT trimLeft(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:43.152620 [ 8431 ] {f5af2a06-5005-4f00-9161-4d1cdcf04e78} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1061, line 1064) (in query: SELECT quantileExactLow();) 2025.06.13 15:44:43.163765 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:43.220297 [ 5978 ] {8408a13f-b6a9-4b09-a3e1-e307fdb58948} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 817, line 818) (in query: SELECT lttb(-1);) 2025.06.13 15:44:43.243508 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:43.290306 [ 8431 ] {49a182fd-2a8b-4a1b-9bc8-3df4a445be7f} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1062, line 1065) (in query: SELECT quantileExactWeighted();) 2025.06.13 15:44:43.314361 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:43.323734 [ 5978 ] {55526bf6-23d0-41ab-9547-99b72f768dab} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 1 argument: In scope SELECT makeDate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 818, line 819) (in query: SELECT makeDate(-1);) 2025.06.13 15:44:43.331041 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 1 argument: In scope SELECT makeDate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:43.465094 [ 8431 ] {4698bf0e-fa7f-4008-b3c8-4b1d1756bd01} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactWeightedInterpolated requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1063, line 1066) (in query: SELECT quantileExactWeightedInterpolated();) 2025.06.13 15:44:43.481845 [ 5978 ] {aa08e341-a066-4c69-8e7a-bc08312e95e7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 1 argument: In scope SELECT makeDate32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 819, line 820) (in query: SELECT makeDate32(-1);) 2025.06.13 15:44:43.483257 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactWeightedInterpolated requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:43.507729 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 1 argument: In scope SELECT makeDate32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:43.611005 [ 8431 ] {af48e3d2-1af3-4451-9b75-3ad43619a1b3} executeQuery: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1064, line 1067) (in query: SELECT quantileGK();) 2025.06.13 15:44:43.619337 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:43.650488 [ 5978 ] {4c1927a1-dd0b-45aa-9ca2-7c9e19bde305} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT makeDateTime(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 820, line 821) (in query: SELECT makeDateTime(-1);) 2025.06.13 15:44:43.662308 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT makeDateTime(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:43.720764 [ 8431 ] {e03ae1e1-25a3-4e29-8a1e-7d0bf65dea4e} executeQuery: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1065, line 1068) (in query: SELECT quantileInterpolatedWeighted();) 2025.06.13 15:44:43.738040 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:43.816478 [ 8431 ] {68689d1d-19e3-4427-b6f5-751f9ac60c7f} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1066, line 1069) (in query: SELECT quantileTDigest();) 2025.06.13 15:44:43.825794 [ 5978 ] {b442704b-da0f-4335-be39-7b2f0d460c17} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 1 argument: In scope SELECT makeDateTime64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 821, line 822) (in query: SELECT makeDateTime64(-1);) 2025.06.13 15:44:43.832432 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:43.834734 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 1 argument: In scope SELECT makeDateTime64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:43.981085 [ 6234 ] {3587debc-bab9-460d-b343-1f51f7967199} executeQuery: Code: 48. DB::Exception: Table engine Join supports only DELETE mutations. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01821_join_table_mutation.sql) (in query: /* ddl_entry=query-0000000005 */ ALTER TABLE test_26vd31d3.join_table_mutation (UPDATE name = 'some' WHERE 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:175: DB::StorageJoin::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x0000000030438cb5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc415b6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:44:44.041591 [ 8431 ] {8cc6ae2f-2aa3-40cc-aafe-0d132f2d941c} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1067, line 1070) (in query: SELECT quantileTDigestWeighted();) 2025.06.13 15:44:44.062233 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:44.065136 [ 5978 ] {6113598e-acc2-43b0-aa6e-e81b9a85b427} executeQuery: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 822, line 823) (in query: SELECT mannWhitneyUTest(-1);) 2025.06.13 15:44:44.078173 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:44.143877 [ 6234 ] {3587debc-bab9-460d-b343-1f51f7967199} executeQuery: Code: 48. DB::Exception: Table engine Join supports only DELETE mutations. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43934) (comment: 01821_join_table_mutation.sql) (query 12, line 23) (in query: ALTER TABLE join_table_mutation UPDATE name = 'some' WHERE 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:175: DB::StorageJoin::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x0000000030438cb5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc415b6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:44:44.146305 [ 8431 ] {374aa015-274e-47b7-9de9-b7ab2d0a1017} executeQuery: Code: 35. DB::Exception: Aggregate function quantileTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1068, line 1071) (in query: SELECT quantileTiming();) 2025.06.13 15:44:44.193579 [ 6234 ] {} TCPHandler: Code: 48. DB::Exception: Table engine Join supports only DELETE mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:175: DB::StorageJoin::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x0000000030438cb5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc415b6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:44:44.199451 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:44.210671 [ 5978 ] {76ea572d-8a49-4a53-aa2e-75138ef5aeac} executeQuery: Code: 42. DB::Exception: Function map requires even number of arguments, but 1 given: In scope SELECT map(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 823, line 824) (in query: SELECT map(-1);) 2025.06.13 15:44:44.220056 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function map requires even number of arguments, but 1 given: In scope SELECT map(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:44.265434 [ 8431 ] {6244ee5f-1d01-4d0e-86f3-ff87c84a641c} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1069, line 1072) (in query: SELECT quantileTimingWeighted();) 2025.06.13 15:44:44.281626 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:44.334782 [ 5978 ] {d8a1abfc-1ae2-459a-8c2d-25ea14c13e00} executeQuery: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 824, line 825) (in query: SELECT mapAdd(-1);) 2025.06.13 15:44:44.444691 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:44.473268 [ 8431 ] {f5838eea-34ab-479f-879f-7aa4f08eb613} executeQuery: Code: 35. DB::Exception: Aggregate function quantiles requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1070, line 1073) (in query: SELECT quantiles();) 2025.06.13 15:44:44.482641 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantiles requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:44.483630 [ 3508 ] {fb841949-1f90-4e7f-a94f-b2b9aa4ee8db::202506_1_76_15} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c14c18 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c06f6e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:44.487551 [ 3508 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fb841949-1f90-4e7f-a94f-b2b9aa4ee8db::202506_1_76_15}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c14c18 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c06f6e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:44.713071 [ 5978 ] {a4e14181-4d8e-4d01-b5cd-596d275e3bc3} executeQuery: Code: 43. DB::Exception: Function mapAll requires at least one argument of type Map: In scope SELECT mapAll(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 825, line 826) (in query: SELECT mapAll(-1);) 2025.06.13 15:44:44.719699 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function mapAll requires at least one argument of type Map: In scope SELECT mapAll(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:44.738946 [ 8431 ] {a9ab2c77-9f8d-496e-87c2-4aa2f547db9f} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1071, line 1074) (in query: SELECT quantilesBFloat16();) 2025.06.13 15:44:44.744727 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:44.811381 [ 5978 ] {e65091d5-d515-4cc1-8a4c-d2bcb4935fc4} executeQuery: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map: In scope SELECT mapApply(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 826, line 827) (in query: SELECT mapApply(-1);) 2025.06.13 15:44:44.832785 [ 8431 ] {36ed70d9-4f97-46d6-9a5d-66d40faf4e78} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1072, line 1075) (in query: SELECT quantilesBFloat16Weighted();) 2025.06.13 15:44:44.833418 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map: In scope SELECT mapApply(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:44.846896 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:44.894586 [ 5110 ] {7daddec9-c94d-435c-9783-85fcb6755e97} executeQuery: Code: 60. DB::Exception: Table test_5.dict_invalidate does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51264) (comment: 01040_dictionary_invalidate_query_switchover_long.sh) (query 1, line 1) (in query: DROP TABLE dict_invalidate), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:44:44.918185 [ 5110 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.dict_invalidate does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:44:45.002318 [ 8431 ] {43768380-9194-40d8-b1ae-15666ca624e4} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1073, line 1076) (in query: SELECT quantilesDD();) 2025.06.13 15:44:45.006308 [ 5978 ] {2d15dcb2-c9f1-4593-9d6d-6ef102b5372e} executeQuery: Code: 43. DB::Exception: Function mapConcat requires at least one argument of type Map: In scope SELECT mapConcat(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 827, line 828) (in query: SELECT mapConcat(-1);) 2025.06.13 15:44:45.008842 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:45.013169 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function mapConcat requires at least one argument of type Map: In scope SELECT mapConcat(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:45.094419 [ 9644 ] {1b2bf01b-12db-48bc-be92-01ba0f706b17} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51248) (comment: 02916_set_formatting.sql) (query 5, line 7) (in query: CREATE TABLE t1 (v UInt64, s String) ENGINE=MergeTree() ORDER BY v;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:44:45.095758 [ 8431 ] {d58d6ee5-d999-4204-b25a-d78fb0c16ede} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1074, line 1077) (in query: SELECT quantilesDeterministic();) 2025.06.13 15:44:45.120854 [ 5978 ] {821c6efe-ef36-4765-b59c-d8f39ac5a61f} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 1, should be 2: In scope SELECT mapContains(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 828, line 829) (in query: SELECT mapContains(-1);) 2025.06.13 15:44:45.121481 [ 9644 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:44:45.133197 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:45.136811 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 1, should be 2: In scope SELECT mapContains(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:45.233243 [ 5978 ] {1988a04a-fa58-44e5-b174-6addf78164cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContainsKeyLike doesn't match: passed 1, should be 2: In scope SELECT mapContainsKeyLike(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 829, line 830) (in query: SELECT mapContainsKeyLike(-1);) 2025.06.13 15:44:45.233417 [ 8431 ] {151a2e1a-610d-418d-85cd-70807c21333a} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1075, line 1078) (in query: SELECT quantilesExact();) 2025.06.13 15:44:45.237866 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContainsKeyLike doesn't match: passed 1, should be 2: In scope SELECT mapContainsKeyLike(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:45.247471 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:45.319337 [ 8431 ] {61689446-6bb3-4f7d-801d-43978ae39693} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesExactExclusive requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1076, line 1079) (in query: SELECT quantilesExactExclusive();) 2025.06.13 15:44:45.329899 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesExactExclusive requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:45.340726 [ 5978 ] {9516863a-5f9b-440c-a374-7263b4a83b07} executeQuery: Code: 43. DB::Exception: Function mapExists requires at least one argument of type Map: In scope SELECT mapExists(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 830, line 831) (in query: SELECT mapExists(-1);) 2025.06.13 15:44:45.349325 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function mapExists requires at least one argument of type Map: In scope SELECT mapExists(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:45.552494 [ 8431 ] {bb1c0063-85ce-423a-be53-f3ef6ce4c989} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1077, line 1080) (in query: SELECT quantilesExactHigh();) 2025.06.13 15:44:45.552739 [ 5978 ] {732042a4-5729-453b-8b86-e3b7728c2bcc} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapExtractKeyLike doesn't match: passed 1, should be 2: In scope SELECT mapExtractKeyLike(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 831, line 832) (in query: SELECT mapExtractKeyLike(-1);) 2025.06.13 15:44:45.559955 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:45.560251 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapExtractKeyLike doesn't match: passed 1, should be 2: In scope SELECT mapExtractKeyLike(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:45.621388 [ 8431 ] {8b0b3310-2cfd-44bf-9766-536ab532ad57} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesExactInclusive requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1078, line 1081) (in query: SELECT quantilesExactInclusive();) 2025.06.13 15:44:45.628993 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesExactInclusive requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:45.632961 [ 5978 ] {42ec4d1f-cf30-4c6a-ad35-783e09548b49} executeQuery: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map: In scope SELECT mapFilter(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 832, line 833) (in query: SELECT mapFilter(-1);) 2025.06.13 15:44:45.639567 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map: In scope SELECT mapFilter(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:45.742406 [ 8431 ] {9e5b090a-9a9f-4dd2-b942-a4b94ede0595} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1079, line 1082) (in query: SELECT quantilesExactLow();) 2025.06.13 15:44:45.761789 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:45.791997 [ 5978 ] {824b75f9-b8ec-4ef9-9fa8-334459ef4383} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 1, should be 2: In scope SELECT mapFromArrays(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 833, line 834) (in query: SELECT mapFromArrays(-1);) 2025.06.13 15:44:45.812821 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 1, should be 2: In scope SELECT mapFromArrays(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:45.856684 [ 8431 ] {faf96b2f-0f62-429b-948e-cc79fb231381} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1080, line 1083) (in query: SELECT quantilesExactWeighted();) 2025.06.13 15:44:45.878495 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:45.909583 [ 3895 ] {15c6e8d6-9fcb-4287-8403-f3ae7ce2f6d9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32856) (comment: 01431_finish_sorting_with_consts.sql) (in query: DROP DATABASE IF EXISTS test_3t9jv1xq SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:44:45.922086 [ 3895 ] {15c6e8d6-9fcb-4287-8403-f3ae7ce2f6d9} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:44:45.934108 [ 5978 ] {78b9d5b6-09f7-4f15-883e-ccda61446c0a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument data_column. Must be String.: In scope SELECT mapFromString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 834, line 835) (in query: SELECT mapFromString(-1);) 2025.06.13 15:44:45.942194 [ 8431 ] {c688a309-3372-48f8-bb33-c207ce548785} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesExactWeightedInterpolated requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1081, line 1084) (in query: SELECT quantilesExactWeightedInterpolated();) 2025.06.13 15:44:45.949929 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument data_column. Must be String.: In scope SELECT mapFromString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:45.965216 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesExactWeightedInterpolated requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:46.044522 [ 18377 ] {c43a11b5-314c-426d-835d-c6e5369288a4} executeQuery: Code: 53. DB::Exception: Cannot convert string '1.0' to type UInt8: In scope SELECT 1 = '1.0'. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51200) (comment: 01311_comparison_with_constant_string.sql) (query 12, line 13) (in query: -- it should work but it doesn't. SELECT 1 = '1.0';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:46.052620 [ 18377 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '1.0' to type UInt8: In scope SELECT 1 = '1.0'. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:46.064911 [ 8099 ] {c8558ddd-9061-46a7-9fbc-de6904ad4050} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51294) (comment: 03217_json_merge_patch_stack_overflow.sql) (query 1, line 3) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 1000000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001cbdcdfa 6. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbdbb77 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb0de8b 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:346: DB::ActionsDAG::addFunction(DB::FunctionNode const&, std::vector>, String) @ 0x000000002cb0ebea 16. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:536: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb7b450 17. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x000000002cb7072c 18. ./build_docker/./src/Planner/Utils.cpp:252: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000002cb8e964 19. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:377: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002ddfe1f7 20. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6eedb 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:46.067376 [ 5978 ] {ac7b9fa7-b109-4464-8956-5aacd2471b7d} executeQuery: Code: 43. DB::Exception: Function mapKeys requires at least one argument of type Map: In scope SELECT mapKeys(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 835, line 836) (in query: SELECT mapKeys(-1);) 2025.06.13 15:44:46.070992 [ 8431 ] {4c4f5929-561c-456c-b513-bfcddd74f52f} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1082, line 1085) (in query: SELECT quantilesGK();) 2025.06.13 15:44:46.079335 [ 8099 ] {} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001cbdcdfa 6. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbdbb77 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb0de8b 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:346: DB::ActionsDAG::addFunction(DB::FunctionNode const&, std::vector>, String) @ 0x000000002cb0ebea 16. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:536: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000002cb7b450 17. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x000000002cb7072c 18. ./build_docker/./src/Planner/Utils.cpp:252: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000002cb8e964 19. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:377: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x000000002ddfe1f7 20. ./build_docker/./src/Planner/Planner.cpp:1593: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6eedb 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:46.080470 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function mapKeys requires at least one argument of type Map: In scope SELECT mapKeys(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:46.083909 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:46.219698 [ 5978 ] {0717c428-082a-43b5-88bf-6eaa9141e15e} executeQuery: Code: 43. DB::Exception: Function mapPartialReverseSort requires at least one argument of type Map: In scope SELECT mapPartialReverseSort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 836, line 837) (in query: SELECT mapPartialReverseSort(-1);) 2025.06.13 15:44:46.229501 [ 8431 ] {59378639-1fca-404b-80a7-b27e01a91b3c} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1083, line 1086) (in query: SELECT quantilesInterpolatedWeighted();) 2025.06.13 15:44:46.231281 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function mapPartialReverseSort requires at least one argument of type Map: In scope SELECT mapPartialReverseSort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:46.252628 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:46.355561 [ 5978 ] {dd213497-afbe-42f5-b612-d0501fbfee18} executeQuery: Code: 43. DB::Exception: Function mapPartialSort requires at least one argument of type Map: In scope SELECT mapPartialSort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 837, line 838) (in query: SELECT mapPartialSort(-1);) 2025.06.13 15:44:46.375735 [ 8431 ] {ccabf1cb-d72a-4de7-bbcc-2322e0623744} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1084, line 1087) (in query: SELECT quantilesTDigest();) 2025.06.13 15:44:46.377587 [ 8099 ] {e5235af2-b95a-42e0-b8b3-ff2ac6d5863f} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 100000)). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51294) (comment: 03217_json_merge_patch_stack_overflow.sql) (query 2, line 4) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 100000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001cbdcdfa 6. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbdbb77 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:46.393400 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function mapPartialSort requires at least one argument of type Map: In scope SELECT mapPartialSort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:46.398593 [ 8099 ] {} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 100000)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001cbdcdfa 6. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbdbb77 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:46.401436 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:46.591705 [ 5978 ] {7b4f8125-76ca-45ac-aa83-de29d5d88a00} executeQuery: Code: 43. DB::Exception: Function mapPopulateSeries only accepts one map or arrays, but got Int8: In scope SELECT mapPopulateSeries(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 838, line 839) (in query: SELECT mapPopulateSeries(-1);) 2025.06.13 15:44:46.600969 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function mapPopulateSeries only accepts one map or arrays, but got Int8: In scope SELECT mapPopulateSeries(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:46.626682 [ 8431 ] {63e42ab4-ff79-4b38-9887-dd1d00d2843e} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1085, line 1088) (in query: SELECT quantilesTDigestWeighted();) 2025.06.13 15:44:46.628924 [ 8099 ] {73cdbfdf-b3b9-4f51-a91f-17d0e5229528} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 10000)). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51294) (comment: 03217_json_merge_patch_stack_overflow.sql) (query 3, line 5) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 10000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001cbdcdfa 6. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbdbb77 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:46.639700 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:46.640564 [ 8099 ] {} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 10000)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001cbdcdfa 6. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbdbb77 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:46.762783 [ 8431 ] {2d24f858-004e-47ef-8e1a-5b1cc11b78fc} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1086, line 1089) (in query: SELECT quantilesTiming();) 2025.06.13 15:44:46.765404 [ 8099 ] {96c6e541-bfc0-42b0-80d0-4668148f2545} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 1000)). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51294) (comment: 03217_json_merge_patch_stack_overflow.sql) (query 4, line 6) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 1000));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001cbdcdfa 6. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbdbb77 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:46.765481 [ 5978 ] {cef246c1-fdd6-4b97-90d4-660e7b85536e} executeQuery: Code: 43. DB::Exception: Function mapReverseSort requires at least one argument of type Map: In scope SELECT mapReverseSort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 839, line 840) (in query: SELECT mapReverseSort(-1);) 2025.06.13 15:44:46.775688 [ 8099 ] {} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 1000)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001cbdcdfa 6. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbdbb77 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:46.776409 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:46.787369 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function mapReverseSort requires at least one argument of type Map: In scope SELECT mapReverseSort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:46.941254 [ 5978 ] {05a5190c-917d-4e59-9cc3-ad5b9a4459a5} executeQuery: Code: 43. DB::Exception: Function mapSort requires at least one argument of type Map: In scope SELECT mapSort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 840, line 841) (in query: SELECT mapSort(-1);) 2025.06.13 15:44:46.945309 [ 8431 ] {d4ff885f-3880-4d8e-8bbf-eae7c5c76edd} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1087, line 1090) (in query: SELECT quantilesTimingWeighted();) 2025.06.13 15:44:46.945662 [ 8099 ] {f97429c9-a799-4a13-8d80-83032cc743b5} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 100)). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51294) (comment: 03217_json_merge_patch_stack_overflow.sql) (query 5, line 7) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 100));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001cbdcdfa 6. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbdbb77 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:46.950891 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function mapSort requires at least one argument of type Map: In scope SELECT mapSort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:46.954238 [ 8099 ] {} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 100)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001cbdcdfa 6. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbdbb77 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:46.957132 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:47.031814 [ 8099 ] {08ea584a-e579-4c21-a837-1801d7b70761} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 10)). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51294) (comment: 03217_json_merge_patch_stack_overflow.sql) (query 6, line 8) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 10));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001cbdcdfa 6. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbdbb77 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:47.032010 [ 5978 ] {08b95442-6c99-4f36-9c31-22a66df5cd99} executeQuery: Code: 42. DB::Exception: mapSubtract accepts at least two maps or map tuples: In scope SELECT mapSubtract(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 841, line 842) (in query: SELECT mapSubtract(-1);) 2025.06.13 15:44:47.041164 [ 8099 ] {} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 10)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001cbdcdfa 6. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbdbb77 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:47.041885 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: mapSubtract accepts at least two maps or map tuples: In scope SELECT mapSubtract(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:47.151718 [ 8099 ] {15318c45-3741-49f1-bc90-632eae3e7606} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 1)). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51294) (comment: 03217_json_merge_patch_stack_overflow.sql) (query 7, line 9) (in query: SELECT JSONMergePatch(REPEAT('{"c":', 1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001cbdcdfa 6. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbdbb77 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:47.160856 [ 8431 ] {345e327e-e363-41b9-914b-67144b592e80} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 0, should be 1: In scope SELECT queryString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1089, line 1092) (in query: SELECT queryString();) 2025.06.13 15:44:47.161912 [ 5978 ] {61406af2-a1fb-4c48-ae51-3c77f3e0067f} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 1, should be 2: In scope SELECT mapUpdate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 842, line 843) (in query: SELECT mapUpdate(-1);) 2025.06.13 15:44:47.168818 [ 8099 ] {} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Invalid value.: In scope SELECT JSONMergePatch(REPEAT('{"c":', 1)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000001cbdcdfa 6. DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001cbdbb77 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:44:47.170354 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 0, should be 1: In scope SELECT queryString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:47.199976 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 1, should be 2: In scope SELECT mapUpdate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:47.293938 [ 8431 ] {eb02a3ab-e875-40ed-aec4-cc514d66cc23} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 0, should be 1: In scope SELECT queryStringAndFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1090, line 1093) (in query: SELECT queryStringAndFragment();) 2025.06.13 15:44:47.315669 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 0, should be 1: In scope SELECT queryStringAndFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:47.355039 [ 5978 ] {6be521b9-3cf2-43d3-acdb-b92c1a93a2fc} executeQuery: Code: 43. DB::Exception: Function mapValues requires at least one argument of type Map: In scope SELECT mapValues(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 843, line 844) (in query: SELECT mapValues(-1);) 2025.06.13 15:44:47.366479 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Function mapValues requires at least one argument of type Map: In scope SELECT mapValues(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:47.484948 [ 5978 ] {f5007cdf-e156-4558-b145-fffcd195eebb} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 1, should be 2: In scope SELECT match(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 844, line 845) (in query: SELECT match(-1);) 2025.06.13 15:44:47.501092 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 1, should be 2: In scope SELECT match(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:47.696186 [ 8431 ] {482cc10c-b6a0-494e-aefc-d2be514032ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 0, should be 1: In scope SELECT radians(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1092, line 1095) (in query: SELECT radians();) 2025.06.13 15:44:47.705663 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 0, should be 1: In scope SELECT radians(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:47.927511 [ 5978 ] {602f427f-8a0d-4e4f-8487-c9572eb25842} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 1, should be 2: In scope SELECT max2(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 847, line 848) (in query: SELECT max2(-1);) 2025.06.13 15:44:47.968519 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 1, should be 2: In scope SELECT max2(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:48.104954 [ 5978 ] {39e8eb03-0b08-4f8d-bda1-81d6215df9a9} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 848, line 849) (in query: SELECT maxIntersections(-1);) 2025.06.13 15:44:48.142441 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:48.240337 [ 5978 ] {874d4eea-b0e3-4a1e-a100-f679d8c0c360} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 849, line 850) (in query: SELECT maxIntersectionsPosition(-1);) 2025.06.13 15:44:48.244271 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:48.394592 [ 18510 ] {b22ec727-dc42-40d1-b012-f969ae2acd13} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51360) (comment: 03040_dynamic_type_alters_2_wide_merge_tree.sql) (query 5, line 6) (in query: CREATE TABLE test (`x` UInt64, `y` UInt64) ENGINE = MergeTree ORDER BY x SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity = 52561, 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 = 360087206, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 24257406, merge_max_block_size = 842, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 26822779, 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 = 23145, primary_key_compress_block_size = 58920, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:44:48.411134 [ 8431 ] {64daaa51-18b4-4c36-8f88-373d0d460115} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randBernoulli. Should be 1 or 2: In scope SELECT randBernoulli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1096, line 1099) (in query: SELECT randBernoulli();) 2025.06.13 15:44:48.427944 [ 5978 ] {a2d63d60-0715-4500-ad0e-ae487d5cd901} executeQuery: Code: 43. DB::Exception: When function maxMappedArrays gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 850, line 851) (in query: SELECT maxMappedArrays(-1);) 2025.06.13 15:44:48.428617 [ 18510 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:44:48.431669 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randBernoulli. Should be 1 or 2: In scope SELECT randBernoulli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:48.433045 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: When function maxMappedArrays gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:48.535601 [ 8431 ] {ff05d101-988b-4c62-ac6b-3148cd04fc73} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randBinomial. Should be 2 or 3: In scope SELECT randBinomial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1097, line 1100) (in query: SELECT randBinomial();) 2025.06.13 15:44:48.541477 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randBinomial. Should be 2 or 3: In scope SELECT randBinomial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:48.542449 [ 5978 ] {de45c02b-8170-4296-9c47-a5b11ad2bd50} executeQuery: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 851, line 852) (in query: SELECT meanZTest(-1);) 2025.06.13 15:44:48.553222 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:48.773364 [ 8431 ] {120ee5ea-8282-4678-b5c6-4549deafe2e8} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randChiSquared. Should be 1 or 2: In scope SELECT randChiSquared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1099, line 1102) (in query: SELECT randChiSquared();) 2025.06.13 15:44:48.813891 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randChiSquared. Should be 1 or 2: In scope SELECT randChiSquared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:49.029731 [ 8431 ] {2b861449-95a2-49af-ac0a-23068bdcb7ce} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randExponential. Should be 1 or 2: In scope SELECT randExponential(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1101, line 1104) (in query: SELECT randExponential();) 2025.06.13 15:44:49.046908 [ 5978 ] {5e64f817-2b27-41c1-a3cf-f96a4bcd1cc5} executeQuery: Code: 42. DB::Exception: Aggregate function quantileBFloat16Weighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 854, line 855) (in query: SELECT medianBFloat16Weighted(-1);) 2025.06.13 15:44:49.053000 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randExponential. Should be 1 or 2: In scope SELECT randExponential(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:49.058965 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileBFloat16Weighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:49.120255 [ 8431 ] {fe5eb816-f539-4738-b94a-8008567dc216} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randFisherF. Should be 2 or 3: In scope SELECT randFisherF(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1102, line 1105) (in query: SELECT randFisherF();) 2025.06.13 15:44:49.152625 [ 18377 ] {58c4bb9b-0ae6-4316-b31e-06fd4008a0af} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: while converting '' to UInt8: In scope SELECT 0 = ''. (ATTEMPT_TO_READ_AFTER_EOF) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51200) (comment: 01311_comparison_with_constant_string.sql) (query 28, line 33) (in query: SELECT 0 = '';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x0000000023b6580e 6. ./src/IO/ReadHelpers.h:537: void DB::readIntTextUnsafe(unsigned long&, DB::ReadBuffer&) @ 0x000000002c5f6614 7. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:30: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002c5f6139 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e257bab 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 10. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 11. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:44:49.156256 [ 5978 ] {8ad47843-e89c-4598-bb12-11915285a4fe} executeQuery: Code: 42. DB::Exception: Aggregate function quantileDD requires at least one param. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 855, line 856) (in query: SELECT medianDD(-1);) 2025.06.13 15:44:49.228074 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randFisherF. Should be 2 or 3: In scope SELECT randFisherF(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:49.237625 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileDD requires at least one param. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:49.240092 [ 18377 ] {} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: while converting '' to UInt8: In scope SELECT 0 = ''. (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x0000000023b6580e 6. ./src/IO/ReadHelpers.h:537: void DB::readIntTextUnsafe(unsigned long&, DB::ReadBuffer&) @ 0x000000002c5f6614 7. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:30: DB::SerializationNumber::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000002c5f6139 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e257bab 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 10. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 11. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:44:49.369596 [ 8431 ] {ef8f2359-1fd9-4cea-a6a0-b7a4ab8f1d9a} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randLogNormal. Should be 2 or 3: In scope SELECT randLogNormal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1103, line 1106) (in query: SELECT randLogNormal();) 2025.06.13 15:44:49.380688 [ 5978 ] {a6be0df1-196f-4995-85be-0b20264e6c38} executeQuery: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 856, line 857) (in query: SELECT medianDeterministic(-1);) 2025.06.13 15:44:49.398123 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randLogNormal. Should be 2 or 3: In scope SELECT randLogNormal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:49.401614 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:49.503820 [ 8431 ] {5ac7e370-b6ca-4e14-9d28-aea8f55a5939} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randNegativeBinomial. Should be 2 or 3: In scope SELECT randNegativeBinomial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1104, line 1107) (in query: SELECT randNegativeBinomial();) 2025.06.13 15:44:49.512409 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randNegativeBinomial. Should be 2 or 3: In scope SELECT randNegativeBinomial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:49.614075 [ 8431 ] {df3930ac-b1a4-408d-8f79-011f646c86cc} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randNormal. Should be 2 or 3: In scope SELECT randNormal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1105, line 1108) (in query: SELECT randNormal();) 2025.06.13 15:44:49.745419 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randNormal. Should be 2 or 3: In scope SELECT randNormal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:49.864148 [ 8431 ] {1f93365a-351e-4ad2-8de0-fcf52776b9b4} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randPoisson. Should be 1 or 2: In scope SELECT randPoisson(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1106, line 1109) (in query: SELECT randPoisson();) 2025.06.13 15:44:49.889582 [ 18602 ] {07d04363-6e3a-4fc1-b3b7-dddd16ac41c3} 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.20286.altinityantalya (altinity build)) (from [::1]:51446) (comment: 02933_sqid.sql) (query 3, line 6) (in query: SELECT sqidEncode();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionSqidEncode::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020882cd8 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:44:49.896018 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randPoisson. Should be 1 or 2: In scope SELECT randPoisson(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:49.918820 [ 18602 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionSqidEncode::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020882cd8 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:44:50.096011 [ 8431 ] {d4c1892d-4998-464b-8ec3-05606a71456c} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randStudentT. Should be 1 or 2: In scope SELECT randStudentT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1107, line 1110) (in query: SELECT randStudentT();) 2025.06.13 15:44:50.109439 [ 18602 ] {fa79a533-c7b6-431a-8325-b407feb3ff52} 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.20286.altinityantalya (altinity build)) (from [::1]:51446) (comment: 02933_sqid.sql) (query 4, line 7) (in query: SELECT sqidDecode();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:44:50.114464 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randStudentT. Should be 1 or 2: In scope SELECT randStudentT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:50.124679 [ 18602 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:44:50.134229 [ 5978 ] {87c65794-b452-4ebd-817e-d94f7723f335} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 860, line 861) (in query: SELECT medianExactWeighted(-1);) 2025.06.13 15:44:50.142130 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:50.260854 [ 8431 ] {1a1fc3f9-6ae1-4764-a28c-a10c61b11645} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randUniform. Should be 2 or 3: In scope SELECT randUniform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1108, line 1111) (in query: SELECT randUniform();) 2025.06.13 15:44:50.309706 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randUniform. Should be 2 or 3: In scope SELECT randUniform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:50.322145 [ 5978 ] {6e1329a3-4a8e-49c2-b08c-ecba2addd9f1} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactWeightedInterpolated requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 861, line 862) (in query: SELECT medianExactWeightedInterpolated(-1);) 2025.06.13 15:44:50.328521 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactWeightedInterpolated requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:50.377279 [ 8431 ] {01148005-76a2-424d-9332-7f6304b08eec} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 0, should be 1: In scope SELECT randomFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1109, line 1112) (in query: SELECT randomFixedString();) 2025.06.13 15:44:50.381586 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 0, should be 1: In scope SELECT randomFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:50.428973 [ 5978 ] {f7b13d92-a99b-481c-90ec-a68970eff6a2} executeQuery: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one param. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 862, line 863) (in query: SELECT medianGK(-1);) 2025.06.13 15:44:50.461775 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one param. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:50.487172 [ 18602 ] {6f0f1102-a050-494c-8256-7735f715f173} 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.20286.altinityantalya (altinity build)) (from [::1]:51446) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x00000000208856ef 5. DB::FunctionSqidEncode::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020882ba8 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:44:50.494875 [ 18602 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x00000000208856ef 5. DB::FunctionSqidEncode::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000020882ba8 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:44:50.552466 [ 8431 ] {5d4b3d4f-8838-492b-b6df-0454352a825a} executeQuery: Code: 42. DB::Exception: Function randomPrintableASCII requires at least one argument: the size of resulting string: In scope SELECT randomPrintableASCII(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1110, line 1113) (in query: SELECT randomPrintableASCII();) 2025.06.13 15:44:50.571211 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function randomPrintableASCII requires at least one argument: the size of resulting string: In scope SELECT randomPrintableASCII(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:50.615546 [ 5978 ] {8bc0896a-2d94-4834-88e3-19f9e0ca1e42} executeQuery: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 863, line 864) (in query: SELECT medianInterpolatedWeighted(-1);) 2025.06.13 15:44:50.628165 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:50.651265 [ 18602 ] {89d3c93f-07de-4b50-aaa0-ca74baffba25} 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.20286.altinityantalya (altinity build)) (from [::1]:51446) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionSqidDecode::getReturnTypeImpl(std::vector> const&) const @ 0x000000002088706a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:50.681949 [ 18602 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionSqidDecode::getReturnTypeImpl(std::vector> const&) const @ 0x000000002088706a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:44:50.694961 [ 8431 ] {334e3771-bd18-497d-9d94-34abe023dbb0} executeQuery: Code: 42. DB::Exception: Function randomString requires at least one argument: the size of resulting string: In scope SELECT randomString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1111, line 1114) (in query: SELECT randomString();) 2025.06.13 15:44:50.707382 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function randomString requires at least one argument: the size of resulting string: In scope SELECT randomString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:50.898757 [ 8431 ] {3a9e4a00-db4b-4d5b-bdf8-5017ebb26fc1} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 0, should be 1: In scope SELECT randomStringUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1112, line 1115) (in query: SELECT randomStringUTF8();) 2025.06.13 15:44:50.904647 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 0, should be 1: In scope SELECT randomStringUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:50.976107 [ 8431 ] {f4bc07bf-1ac2-41f6-a9cc-4c05635c246d} executeQuery: Code: 42. DB::Exception: Function range needs 1..3 arguments; passed 0.: In scope SELECT range(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1113, line 1116) (in query: SELECT range();) 2025.06.13 15:44:50.986509 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function range needs 1..3 arguments; passed 0.: In scope SELECT range(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:51.242197 [ 5978 ] {ef7c1f31-5615-4e4a-a6b0-aaa2b833415a} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 865, line 866) (in query: SELECT medianTDigestWeighted(-1);) 2025.06.13 15:44:51.250298 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:51.352967 [ 8431 ] {a1b7f3b5-5689-4919-8d47-5e3acd29bfde} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1114, line 1117) (in query: SELECT rank();) 2025.06.13 15:44:51.422961 [ 8431 ] {} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:44:51.485056 [ 8431 ] {1708af60-d09e-4b12-955a-79524d1a22b3} executeQuery: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1115, line 1118) (in query: SELECT rankCorr();) 2025.06.13 15:44:51.494047 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:51.592758 [ 8431 ] {e59be8d2-a9d5-409a-9f76-af366ef0e4f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 0, should be 1: In scope SELECT readWKTLineString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1116, line 1119) (in query: SELECT readWKTLineString();) 2025.06.13 15:44:51.594692 [ 5978 ] {4cde9976-b530-497c-ae60-c474113a112e} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 867, line 868) (in query: SELECT medianTimingWeighted(-1);) 2025.06.13 15:44:51.606869 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 0, should be 1: In scope SELECT readWKTLineString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:51.682420 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:51.752378 [ 8431 ] {50130d81-33c6-4d6d-899b-e737761cc18d} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 0, should be 1: In scope SELECT readWKTMultiLineString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1117, line 1120) (in query: SELECT readWKTMultiLineString();) 2025.06.13 15:44:51.824202 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 0, should be 1: In scope SELECT readWKTMultiLineString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:51.885564 [ 8431 ] {a89d6b0c-1c63-4e6f-b135-4f9a14b57e6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 0, should be 1: In scope SELECT readWKTMultiPolygon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1118, line 1121) (in query: SELECT readWKTMultiPolygon();) 2025.06.13 15:44:51.896622 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 0, should be 1: In scope SELECT readWKTMultiPolygon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:52.022491 [ 5978 ] {4b6113b1-e51e-4616-9b5f-26eb36a957ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 1, should be 2 or 3: In scope SELECT mid(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 869, line 870) (in query: SELECT mid(-1);) 2025.06.13 15:44:52.028962 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 1, should be 2 or 3: In scope SELECT mid(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:52.129756 [ 8431 ] {d3590873-d1b3-4e20-bd48-4ea754b60bc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 0, should be 1: In scope SELECT readWKTPoint(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1119, line 1122) (in query: SELECT readWKTPoint();) 2025.06.13 15:44:52.135899 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 0, should be 1: In scope SELECT readWKTPoint(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:52.263862 [ 8431 ] {f9ce41f6-d61d-43d1-aa3c-4879a7f04f38} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 0, should be 1: In scope SELECT readWKTPolygon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1120, line 1123) (in query: SELECT readWKTPolygon();) 2025.06.13 15:44:52.271956 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 0, should be 1: In scope SELECT readWKTPolygon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:52.361538 [ 5978 ] {b81d167a-7431-400a-be1b-3f884033acba} executeQuery: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 1, should be 2: In scope SELECT min2(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 871, line 872) (in query: SELECT min2(-1);) 2025.06.13 15:44:52.366941 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 1, should be 2: In scope SELECT min2(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:52.405910 [ 8431 ] {a7cebcfd-74af-45b2-bcb4-6b55fb1f8cd5} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 0, should be 1: In scope SELECT readWKTRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1121, line 1124) (in query: SELECT readWKTRing();) 2025.06.13 15:44:52.430220 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 0, should be 1: In scope SELECT readWKTRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:52.504215 [ 5978 ] {63e2df8e-25e9-4f52-9fa5-5de37d103957} executeQuery: Code: 43. DB::Exception: When function minMappedArrays gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 872, line 873) (in query: SELECT minMappedArrays(-1);) 2025.06.13 15:44:52.529405 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: When function minMappedArrays gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:52.635769 [ 8431 ] {2774e37a-a325-4e59-b537-e9e7b0ee6152} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 0: In scope SELECT regexpExtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1122, line 1125) (in query: SELECT regexpExtract();) 2025.06.13 15:44:52.636367 [ 18510 ] {f46e8e9e-7f85-4d0d-ac36-6b111cbf3789} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51552) (comment: 02033_join_engine_deadlock_long.sh) (query 1, line 2) (in query: CREATE TABLE join_block_test ( id String, num Int64 ) ENGINE = Join(ANY, LEFT, id) ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:52.642993 [ 18510 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:52.654182 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 0: In scope SELECT regexpExtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:52.660016 [ 5978 ] {c0a53dfe-0332-4bdf-a35d-a44ed9fe46c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 1, should be 5: In scope SELECT minSampleSizeContinous(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 873, line 874) (in query: SELECT minSampleSizeContinous(-1);) 2025.06.13 15:44:52.687731 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 1, should be 5: In scope SELECT minSampleSizeContinous(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:52.786567 [ 8431 ] {6a1f43b5-d1ee-400d-859b-8c50c383bc6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 0, should be 1: In scope SELECT regexpQuoteMeta(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1123, line 1126) (in query: SELECT regexpQuoteMeta();) 2025.06.13 15:44:52.808016 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 0, should be 1: In scope SELECT regexpQuoteMeta(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:52.831273 [ 5978 ] {19af4e5c-a5c6-4fce-96ef-0d2c84e387db} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 1, should be 5: In scope SELECT minSampleSizeContinuous(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 874, line 875) (in query: SELECT minSampleSizeContinuous(-1);) 2025.06.13 15:44:52.856079 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 1, should be 5: In scope SELECT minSampleSizeContinuous(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:52.967045 [ 8431 ] {0a7fbdb7-bde1-4242-ada3-8deac26ef9e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionHierarchy doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1124, line 1127) (in query: SELECT regionHierarchy();) 2025.06.13 15:44:52.980377 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionHierarchy doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:52.982514 [ 5978 ] {940e7c51-187e-459c-b142-db42570ac337} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 1, should be 4: In scope SELECT minSampleSizeConversion(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 875, line 876) (in query: SELECT minSampleSizeConversion(-1);) 2025.06.13 15:44:52.986819 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 1, should be 4: In scope SELECT minSampleSizeConversion(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:53.036422 [ 8431 ] {1487ca5a-19a3-4dec-b621-0eb472ad0142} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionIn doesn't match: passed 0, should be 2 or 3.: In scope SELECT regionIn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1125, line 1128) (in query: SELECT regionIn();) 2025.06.13 15:44:53.041298 [ 5978 ] {219f948d-8fdc-4826-b54f-246f3d3df9cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 1, should be 2: In scope SELECT minus(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 876, line 877) (in query: SELECT minus(-1);) 2025.06.13 15:44:53.054289 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionIn doesn't match: passed 0, should be 2 or 3.: In scope SELECT regionIn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:53.058338 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 1, should be 2: In scope SELECT minus(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:53.130126 [ 9642 ] {06d67989-1ccf-4812-b019-fc2146073079} executeQuery: Code: 60. DB::Exception: Table test_11.join_block_test does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54208) (comment: 02033_join_engine_deadlock_long.sh) (query 1, line 2) (in query: INSERT INTO join_block_test SELECT toString(number) as id, number * number as num FROM system.numbers LIMIT 500000 ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.134220 [ 8431 ] {e7881eef-a6f2-4783-8d66-0f81c2f58ba7} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToArea doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToArea(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1126, line 1129) (in query: SELECT regionToArea();) 2025.06.13 15:44:53.148352 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToArea doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToArea(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:53.157196 [ 5978 ] {1ea234a8-bb1d-4eba-b758-52b77b512638} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 1, should be 2: In scope SELECT mismatches(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 877, line 878) (in query: SELECT mismatches(-1);) 2025.06.13 15:44:53.161367 [ 9642 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.join_block_test does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.165218 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 1, should be 2: In scope SELECT mismatches(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:53.208604 [ 8431 ] {ca7ade9c-74af-4405-bcdc-64dd4fb70b30} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToCity doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToCity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1127, line 1130) (in query: SELECT regionToCity();) 2025.06.13 15:44:53.224781 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToCity doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToCity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:53.268110 [ 5978 ] {b035aa96-700f-42c9-81f3-558b500c1a57} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 1, should be 2: In scope SELECT mod(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 878, line 879) (in query: SELECT mod(-1);) 2025.06.13 15:44:53.269807 [ 4172 ] {7893c13f-c03d-485c-872d-9af833c25ab3} executeQuery: Code: 60. DB::Exception: Table test_11.join_block_test does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54256) (comment: 02033_join_engine_deadlock_long.sh) (query 1, line 2) (in query: INSERT INTO join_block_test SELECT toString(number) as id, number * number as num FROM system.numbers LIMIT 500000 ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.295956 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 1, should be 2: In scope SELECT mod(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:53.298263 [ 4172 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.join_block_test does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.377819 [ 18510 ] {0d774a8b-2670-46b6-a8ad-4dcc2f81e78e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'join_block_test' in scope SELECT * FROM join_block_test AS i1 ANY LEFT JOIN (SELECT * FROM join_block_test) AS i2 ON i1.id = toString(i2.num). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54224) (comment: 02033_join_engine_deadlock_long.sh) (query 1, line 2) (in query: SELECT * FROM ( SELECT toString(number) AS user_id FROM system.numbers LIMIT 10000 OFFSET 20000 ) AS t1 LEFT JOIN ( SELECT * FROM join_block_test AS i1 ANY LEFT JOIN ( SELECT * FROM join_block_test ) AS i2 ON i1.id = toString(i2.num) ) AS t2 ON t1.user_id = t2.id ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc52d97 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.398931 [ 18510 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'join_block_test' in scope SELECT * FROM join_block_test AS i1 ANY LEFT JOIN (SELECT * FROM join_block_test) AS i2 ON i1.id = toString(i2.num). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc52d97 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.527608 [ 8431 ] {b572888d-dabe-4894-bba4-450296c45dad} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToContinent doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToContinent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1128, line 1131) (in query: SELECT regionToContinent();) 2025.06.13 15:44:53.527813 [ 5978 ] {9699b73f-283e-488c-9c73-c0ebe15b4466} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 1, should be 2: In scope SELECT modulo(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 879, line 880) (in query: SELECT modulo(-1);) 2025.06.13 15:44:53.532194 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToContinent doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToContinent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:53.532617 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 1, should be 2: In scope SELECT modulo(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:53.656470 [ 5163 ] {5ed9793c-228a-419f-95f3-21a649f731ae} executeQuery: Code: 60. DB::Exception: Table test_11.join_block_test does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54276) (comment: 02033_join_engine_deadlock_long.sh) (query 1, line 2) (in query: INSERT INTO join_block_test SELECT toString(number) as id, number * number as num FROM system.numbers LIMIT 500000 ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.766521 [ 5163 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.join_block_test does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.852263 [ 8431 ] {70d1bb88-be0c-4823-8ea7-6b829334f4c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToCountry doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToCountry(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1129, line 1132) (in query: SELECT regionToCountry();) 2025.06.13 15:44:53.855704 [ 5978 ] {d12108bb-69fe-4ffa-b294-d16773f9fdb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 1, should be 2: In scope SELECT moduloLegacy(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 880, line 881) (in query: SELECT moduloLegacy(-1);) 2025.06.13 15:44:53.860380 [ 3931 ] {d443451c-f0f1-41c0-8cf5-94bbd918ff24} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'join_block_test' in scope SELECT * FROM join_block_test AS i1 ANY LEFT JOIN (SELECT * FROM join_block_test) AS i2 ON i1.id = toString(i2.num). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54260) (comment: 02033_join_engine_deadlock_long.sh) (query 1, line 2) (in query: SELECT * FROM ( SELECT toString(number) AS user_id FROM system.numbers LIMIT 10000 OFFSET 20000 ) AS t1 LEFT JOIN ( SELECT * FROM join_block_test AS i1 ANY LEFT JOIN ( SELECT * FROM join_block_test ) AS i2 ON i1.id = toString(i2.num) ) AS t2 ON t1.user_id = t2.id ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc52d97 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.870917 [ 3821 ] {491a29f4-f4e8-43f6-99a5-667a02e7f8c0} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'join_block_test' in scope SELECT * FROM join_block_test AS i1 ANY LEFT JOIN (SELECT * FROM join_block_test) AS i2 ON i1.id = toString(i2.num). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54302) (comment: 02033_join_engine_deadlock_long.sh) (query 1, line 2) (in query: SELECT * FROM ( SELECT toString(number) AS user_id FROM system.numbers LIMIT 10000 OFFSET 20000 ) AS t1 LEFT JOIN ( SELECT * FROM join_block_test AS i1 ANY LEFT JOIN ( SELECT * FROM join_block_test ) AS i2 ON i1.id = toString(i2.num) ) AS t2 ON t1.user_id = t2.id ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc52d97 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.871457 [ 5005 ] {3d5fc2ff-462f-49a6-88bd-a8e4d9896f06} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'join_block_test' in scope SELECT * FROM join_block_test AS i1 ANY LEFT JOIN (SELECT * FROM join_block_test) AS i2 ON i1.id = toString(i2.num). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54290) (comment: 02033_join_engine_deadlock_long.sh) (query 1, line 2) (in query: SELECT * FROM ( SELECT toString(number) AS user_id FROM system.numbers LIMIT 10000 OFFSET 20000 ) AS t1 LEFT JOIN ( SELECT * FROM join_block_test AS i1 ANY LEFT JOIN ( SELECT * FROM join_block_test ) AS i2 ON i1.id = toString(i2.num) ) AS t2 ON t1.user_id = t2.id ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc52d97 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.874874 [ 4172 ] {58562f75-9b4c-4880-be89-da3ce810f1e7} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'join_block_test' in scope SELECT * FROM join_block_test AS i1 ANY LEFT JOIN (SELECT * FROM join_block_test) AS i2 ON i1.id = toString(i2.num). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54330) (comment: 02033_join_engine_deadlock_long.sh) (query 1, line 2) (in query: SELECT * FROM ( SELECT toString(number) AS user_id FROM system.numbers LIMIT 10000 OFFSET 20000 ) AS t1 LEFT JOIN ( SELECT * FROM join_block_test AS i1 ANY LEFT JOIN ( SELECT * FROM join_block_test ) AS i2 ON i1.id = toString(i2.num) ) AS t2 ON t1.user_id = t2.id ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc52d97 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.876091 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToCountry doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToCountry(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:53.877503 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 1, should be 2: In scope SELECT moduloLegacy(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:53.886741 [ 3931 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'join_block_test' in scope SELECT * FROM join_block_test AS i1 ANY LEFT JOIN (SELECT * FROM join_block_test) AS i2 ON i1.id = toString(i2.num). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc52d97 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.898516 [ 6234 ] {4181941b-2539-4831-8bfd-c1acb337626b} executeQuery: Code: 60. DB::Exception: Table test_11.join_block_test does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54294) (comment: 02033_join_engine_deadlock_long.sh) (query 1, line 2) (in query: INSERT INTO join_block_test SELECT toString(number) as id, number * number as num FROM system.numbers LIMIT 500000 ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.903980 [ 3821 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'join_block_test' in scope SELECT * FROM join_block_test AS i1 ANY LEFT JOIN (SELECT * FROM join_block_test) AS i2 ON i1.id = toString(i2.num). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc52d97 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.912750 [ 5005 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'join_block_test' in scope SELECT * FROM join_block_test AS i1 ANY LEFT JOIN (SELECT * FROM join_block_test) AS i2 ON i1.id = toString(i2.num). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc52d97 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.927481 [ 4172 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'join_block_test' in scope SELECT * FROM join_block_test AS i1 ANY LEFT JOIN (SELECT * FROM join_block_test) AS i2 ON i1.id = toString(i2.num). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5138: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc52d97 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.953366 [ 6234 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.join_block_test does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.954595 [ 8101 ] {5e6ca9d8-17d1-4308-b81f-359b8e064b08} executeQuery: Code: 60. DB::Exception: Table test_11.join_block_test does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54316) (comment: 02033_join_engine_deadlock_long.sh) (query 1, line 2) (in query: INSERT INTO join_block_test SELECT toString(number) as id, number * number as num FROM system.numbers LIMIT 500000 ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:53.998358 [ 8101 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.join_block_test does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:54.041493 [ 5978 ] {99e08485-d8ef-44ad-8ff6-6d3aae11eaa3} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 1, should be 2: In scope SELECT moduloOrZero(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 881, line 882) (in query: SELECT moduloOrZero(-1);) 2025.06.13 15:44:54.058336 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 1, should be 2: In scope SELECT moduloOrZero(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:54.063501 [ 8431 ] {d008ee55-944d-419e-8cb0-65123997793c} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToDistrict doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToDistrict(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1130, line 1133) (in query: SELECT regionToDistrict();) 2025.06.13 15:44:54.106004 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToDistrict doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToDistrict(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:54.193513 [ 8431 ] {104c2496-ffbf-49ab-8180-b9a4ce910634} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToName doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1131, line 1134) (in query: SELECT regionToName();) 2025.06.13 15:44:54.221045 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToName doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:54.226322 [ 5978 ] {a931e29e-70bf-4070-8297-4a494d2fffc1} executeQuery: Code: 43. DB::Exception: Illegal type of argument of function monthName, should be Date, DateTime or DateTime64: In scope SELECT monthName(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 882, line 883) (in query: SELECT monthName(-1);) 2025.06.13 15:44:54.264613 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type of argument of function monthName, should be Date, DateTime or DateTime64: In scope SELECT monthName(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:54.331004 [ 8431 ] {957aa664-6165-4610-896b-b53ccd6d99db} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToPopulation doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToPopulation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1132, line 1135) (in query: SELECT regionToPopulation();) 2025.06.13 15:44:54.370998 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToPopulation doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToPopulation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:54.396767 [ 5978 ] {66a2491d-3fe1-4e80-8118-c3f672358514} executeQuery: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 1, should be 2: In scope SELECT mortonDecode(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 883, line 884) (in query: SELECT mortonDecode(-1);) 2025.06.13 15:44:54.417459 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 1, should be 2: In scope SELECT mortonDecode(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:54.527044 [ 8431 ] {0b44cd8d-942b-418d-b0f1-4dd889da43e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToTopContinent doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToTopContinent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1133, line 1136) (in query: SELECT regionToTopContinent();) 2025.06.13 15:44:54.560770 [ 5978 ] {6f948de0-e447-40e5-937f-ade6d658b068} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument for function mortonEncode, should be a native UInt: In scope SELECT mortonEncode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 884, line 885) (in query: SELECT mortonEncode(-1);) 2025.06.13 15:44:54.568663 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument for function mortonEncode, should be a native UInt: In scope SELECT mortonEncode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:54.577959 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToTopContinent doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToTopContinent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:54.618939 [ 8431 ] {7642ecce-4360-4bbe-ab1c-a91d503ad165} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 0, should be 2: In scope SELECT reinterpret(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1134, line 1137) (in query: SELECT reinterpret();) 2025.06.13 15:44:54.644848 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 0, should be 2: In scope SELECT reinterpret(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:54.663309 [ 4172 ] {25ec34cb-71b3-46de-85f7-1edde85911a2} executeQuery: Code: 60. DB::Exception: Table test_11.join_block_test does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54340) (comment: 02033_join_engine_deadlock_long.sh) (query 1, line 2) (in query: DROP TABLE join_block_test SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:44:54.663458 [ 5978 ] {cac6b95e-9d31-4416-b059-7124dea9dd03} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 1, should be 3: In scope SELECT multiFuzzyMatchAllIndices(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 885, line 886) (in query: SELECT multiFuzzyMatchAllIndices(-1);) 2025.06.13 15:44:54.695729 [ 4172 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.join_block_test does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:44:54.696049 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 1, should be 3: In scope SELECT multiFuzzyMatchAllIndices(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:54.790773 [ 8431 ] {fb5e3fab-6514-4bfd-b3a8-bfd598aaf4c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1135, line 1138) (in query: SELECT reinterpretAsDate();) 2025.06.13 15:44:54.797764 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:54.831332 [ 5978 ] {0fe9001b-b572-40cb-9bb6-ee3997b78fb5} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 1, should be 3: In scope SELECT multiFuzzyMatchAny(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 886, line 887) (in query: SELECT multiFuzzyMatchAny(-1);) 2025.06.13 15:44:54.847872 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 1, should be 3: In scope SELECT multiFuzzyMatchAny(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:54.880455 [ 8431 ] {1aac703f-cce1-4328-b569-48a94d20020e} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1136, line 1139) (in query: SELECT reinterpretAsDateTime();) 2025.06.13 15:44:54.900775 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:54.932101 [ 5978 ] {24c759fe-481b-4c0d-9c05-91313e55e781} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 1, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 887, line 888) (in query: SELECT multiFuzzyMatchAnyIndex(-1);) 2025.06.13 15:44:54.941361 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 1, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:54.966389 [ 18380 ] {8cbd7e20-f945-4a7d-8beb-eb324b6366fd} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54374) (comment: 01825_type_json_9.sql) (query 2, line 5) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:54.992846 [ 8431 ] {6367f542-e0d5-4a88-ab6f-5764db59323c} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1137, line 1140) (in query: SELECT reinterpretAsFixedString();) 2025.06.13 15:44:54.997991 [ 18380 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:44:55.006724 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.039670 [ 5978 ] {2d8c1121-80df-462b-b11e-a68f30e21be8} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 888, line 889) (in query: SELECT multiIf(-1);) 2025.06.13 15:44:55.050857 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.085274 [ 8431 ] {b84e0aae-f17c-4257-acdb-d68f4f4cf9af} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1138, line 1141) (in query: SELECT reinterpretAsFloat32();) 2025.06.13 15:44:55.098518 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.134438 [ 5978 ] {8ed9cc6d-8ddf-40ef-a3d3-bfdd4cf0ce4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 1, should be 2: In scope SELECT multiMatchAllIndices(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 889, line 890) (in query: SELECT multiMatchAllIndices(-1);) 2025.06.13 15:44:55.138802 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 1, should be 2: In scope SELECT multiMatchAllIndices(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.185570 [ 8431 ] {767c7a23-ee60-48ec-97ca-edd32074f824} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1139, line 1142) (in query: SELECT reinterpretAsFloat64();) 2025.06.13 15:44:55.194212 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.220461 [ 5978 ] {f11bdf69-bcf5-4179-8251-e4e0a4ab7d04} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 1, should be 2: In scope SELECT multiMatchAny(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 890, line 891) (in query: SELECT multiMatchAny(-1);) 2025.06.13 15:44:55.238578 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 1, should be 2: In scope SELECT multiMatchAny(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.285570 [ 8431 ] {ca55b159-2809-4380-91e4-9844aba2c975} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1140, line 1143) (in query: SELECT reinterpretAsInt128();) 2025.06.13 15:44:55.309710 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.391263 [ 8431 ] {f1f260f0-ab1a-416e-8a68-9851f170ef5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1141, line 1144) (in query: SELECT reinterpretAsInt16();) 2025.06.13 15:44:55.397189 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.400492 [ 5978 ] {9b2a0ad0-a0c0-4e70-8c1c-102019c4f4a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 1, should be 2: In scope SELECT multiMatchAnyIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 891, line 892) (in query: SELECT multiMatchAnyIndex(-1);) 2025.06.13 15:44:55.422312 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 1, should be 2: In scope SELECT multiMatchAnyIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.485558 [ 18602 ] {4dd52426-a6cd-4656-8aa2-74518fa7ee4d} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51446) (comment: 02933_sqid.sql) (query 24, line 31) (in query: CREATE TABLE tab (`id` String) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 36452, 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 = 479166373, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 9666272, merge_max_block_size = 11761, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 123776, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 24052109, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 18, 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 = 39936, primary_key_compress_block_size = 96648, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:44:55.525019 [ 18602 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:44:55.525208 [ 8431 ] {09322310-4814-4613-b306-8eabb90f6363} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1142, line 1145) (in query: SELECT reinterpretAsInt256();) 2025.06.13 15:44:55.555165 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.557282 [ 5978 ] {bb915f99-becc-4bb7-b361-e88cabcbfc16} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositions(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 892, line 893) (in query: SELECT multiSearchAllPositions(-1);) 2025.06.13 15:44:55.586027 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositions(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.723023 [ 8431 ] {d0a934bb-6bf1-4734-8369-cc9c138bc55b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1143, line 1146) (in query: SELECT reinterpretAsInt32();) 2025.06.13 15:44:55.729563 [ 5978 ] {8478eb4d-c12d-4433-9d77-34f1a005fdf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 893, line 894) (in query: SELECT multiSearchAllPositionsCaseInsensitive(-1);) 2025.06.13 15:44:55.751013 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.751085 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.838407 [ 5978 ] {33a0b807-7388-4a70-8e27-323f7f854bc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 894, line 895) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8(-1);) 2025.06.13 15:44:55.849262 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.859835 [ 8431 ] {dfd8c443-53b9-4788-86d7-526fac58d5c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1144, line 1147) (in query: SELECT reinterpretAsInt64();) 2025.06.13 15:44:55.867922 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.942767 [ 5978 ] {216576ad-f94c-4b52-8ad2-32971cc05f7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositionsUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 895, line 896) (in query: SELECT multiSearchAllPositionsUTF8(-1);) 2025.06.13 15:44:55.951949 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAllPositionsUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:55.998366 [ 8431 ] {22dd237b-e7d6-40bd-8c36-9fe79fe8c635} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1145, line 1148) (in query: SELECT reinterpretAsInt8();) 2025.06.13 15:44:56.029671 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.108147 [ 4172 ] {34b73e1b-c529-4e9e-903b-75269f93b410} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54416) (comment: 01635_sum_map_fuzz.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: DB::registerAggregateFunctionSumMap(DB::AggregateFunctionFactory&)::$_3::operator()(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) const @ 0x0000000026aafc01 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:44:56.109296 [ 5978 ] {517a2d3c-2ce5-4186-b27a-6555a78f1679} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 1, should be 2: In scope SELECT multiSearchAny(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 896, line 897) (in query: SELECT multiSearchAny(-1);) 2025.06.13 15:44:56.115976 [ 4172 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: DB::registerAggregateFunctionSumMap(DB::AggregateFunctionFactory&)::$_3::operator()(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) const @ 0x0000000026aafc01 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:44:56.123890 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 1, should be 2: In scope SELECT multiSearchAny(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.140895 [ 8431 ] {aa90de63-6202-4d50-8bf8-056f52e8b25d} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1146, line 1149) (in query: SELECT reinterpretAsString();) 2025.06.13 15:44:56.148797 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.240126 [ 5978 ] {7bdf8d03-1c88-4cf2-aa32-444373934f44} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 897, line 898) (in query: SELECT multiSearchAnyCaseInsensitive(-1);) 2025.06.13 15:44:56.240834 [ 8431 ] {b5544949-b389-4456-a48f-b5f7e4b24aa1} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1147, line 1150) (in query: SELECT reinterpretAsUInt128();) 2025.06.13 15:44:56.279627 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.293812 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.354002 [ 5978 ] {dfe4d7ea-0cc8-4ec8-b46b-fdc756b66b01} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 898, line 899) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8(-1);) 2025.06.13 15:44:56.374147 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.381652 [ 3821 ] {46698c2e-903a-4f03-9f6b-8dc67ac122d5} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54448) (comment: 02184_storage_add_support_ttl.sql) (query 2, line 2) (in query: CREATE TABLE mergeTree_02184 (`id` UInt64, `name` String, `dt` Date) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 54821, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.30485209822654724, replace_long_file_name_to_hash = true, max_file_name_length = 86, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 210441204, compact_parts_max_granules_to_buffer = 210, compact_parts_merge_max_bytes_to_prefetch_part = 20227218, merge_max_block_size = 10702, old_parts_lifetime = 197., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 63, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 17521647, 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 = 16987, primary_key_compress_block_size = 78899, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:44:56.402290 [ 8431 ] {204f8b86-c832-4422-8f10-00c0f8186a66} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1148, line 1151) (in query: SELECT reinterpretAsUInt16();) 2025.06.13 15:44:56.416022 [ 3821 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:44:56.423310 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.494779 [ 5978 ] {ba12530e-addf-4a72-ad6e-3f793746fc51} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAnyUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 899, line 900) (in query: SELECT multiSearchAnyUTF8(-1);) 2025.06.13 15:44:56.499175 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchAnyUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.518603 [ 8431 ] {48245bec-8982-4914-9d7a-01f161b4b26b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1149, line 1152) (in query: SELECT reinterpretAsUInt256();) 2025.06.13 15:44:56.523856 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.614328 [ 5978 ] {644631ab-73f4-42ec-8343-6295a9997515} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 900, line 901) (in query: SELECT multiSearchFirstIndex(-1);) 2025.06.13 15:44:56.620051 [ 8431 ] {87e09803-fff1-4043-bcf8-6cb120b2ddba} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1150, line 1153) (in query: SELECT reinterpretAsUInt32();) 2025.06.13 15:44:56.620325 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.633461 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.693200 [ 5978 ] {453811b9-d85e-4311-8814-d5bd6ede78c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 901, line 902) (in query: SELECT multiSearchFirstIndexCaseInsensitive(-1);) 2025.06.13 15:44:56.697082 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.724716 [ 8431 ] {1854ba4f-0205-4701-a51b-b690e5e30a07} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1151, line 1154) (in query: SELECT reinterpretAsUInt64();) 2025.06.13 15:44:56.743891 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.800377 [ 5978 ] {3a213e7c-dad0-4388-8528-72a38f9f831a} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 902, line 903) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8(-1);) 2025.06.13 15:44:56.843961 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.914078 [ 8431 ] {b50702e6-ce16-44b6-ab7a-f3e5188a808d} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1152, line 1155) (in query: SELECT reinterpretAsUInt8();) 2025.06.13 15:44:56.931838 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:56.971533 [ 5978 ] {aefd4c7b-8815-4b71-a4b1-99e8b64127f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndexUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 903, line 904) (in query: SELECT multiSearchFirstIndexUTF8(-1);) 2025.06.13 15:44:56.984295 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstIndexUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:57.032585 [ 8431 ] {fdb93bca-3ff4-4f40-9ea4-e69213392021} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1153, line 1156) (in query: SELECT reinterpretAsUUID();) 2025.06.13 15:44:57.039157 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:57.135000 [ 5978 ] {bcd16142-6662-474f-a712-eb7bcb1382eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPosition(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 904, line 905) (in query: SELECT multiSearchFirstPosition(-1);) 2025.06.13 15:44:57.143079 [ 8431 ] {8dcbb882-89ff-442e-ba4a-452e8d17c15b} executeQuery: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 0, should be 2: In scope SELECT repeat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1154, line 1157) (in query: SELECT repeat();) 2025.06.13 15:44:57.143160 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPosition(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:57.155652 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 0, should be 2: In scope SELECT repeat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:57.243573 [ 8431 ] {dc28e8a2-140b-4edf-ae2a-378e28dd0d97} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 0, should be 3: In scope SELECT replace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1155, line 1158) (in query: SELECT replace();) 2025.06.13 15:44:57.262138 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 0, should be 3: In scope SELECT replace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:57.280028 [ 5978 ] {5ea0df8e-da79-45fd-9401-f358b3f40d66} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 905, line 906) (in query: SELECT multiSearchFirstPositionCaseInsensitive(-1);) 2025.06.13 15:44:57.306544 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:57.424717 [ 5978 ] {88cd8558-7cfd-44cd-93c1-91f93c148bcb} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 906, line 907) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8(-1);) 2025.06.13 15:44:57.432269 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:57.436497 [ 8431 ] {97400f6f-c9c2-4426-9928-77b2043e4246} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 0, should be 3: In scope SELECT replaceAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1156, line 1159) (in query: SELECT replaceAll();) 2025.06.13 15:44:57.452124 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 0, should be 3: In scope SELECT replaceAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:57.529109 [ 5978 ] {d22c5dd7-34d5-445b-930e-f02e97ed5bb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPositionUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 907, line 908) (in query: SELECT multiSearchFirstPositionUTF8(-1);) 2025.06.13 15:44:57.548544 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 1, should be 2: In scope SELECT multiSearchFirstPositionUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:57.552090 [ 8431 ] {239cadc6-6a39-47e0-98d8-de47fd85f40f} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 0, should be 3: In scope SELECT replaceOne(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1157, line 1160) (in query: SELECT replaceOne();) 2025.06.13 15:44:57.558562 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 0, should be 3: In scope SELECT replaceOne(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:57.600099 [ 4171 ] {cea9d3c1-ba62-4f8e-95c1-bfe5f39173b2} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54556) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf46bd 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213d4c9 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:44:57.616524 [ 5978 ] {d5513dda-987e-4fef-abcf-17b4db63e54d} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT multiply(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 908, line 909) (in query: SELECT multiply(-1);) 2025.06.13 15:44:57.620408 [ 4171 ] {} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1267: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf46bd 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213d4c9 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:44:57.638786 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT multiply(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:57.669143 [ 8431 ] {812edf87-daca-4fc7-871d-6df8083f385a} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 0, should be 3: In scope SELECT replaceRegexpAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1158, line 1161) (in query: SELECT replaceRegexpAll();) 2025.06.13 15:44:57.681976 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 0, should be 3: In scope SELECT replaceRegexpAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:57.740866 [ 5978 ] {7e13e5b7-02bd-422c-80a9-d848d2da22e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiplyDecimal does not match: 2 or 3 expected: In scope SELECT multiplyDecimal(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 909, line 910) (in query: SELECT multiplyDecimal(-1);) 2025.06.13 15:44:57.743969 [ 8431 ] {6798e698-748b-4f14-aa17-578b061b1521} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 0, should be 3: In scope SELECT replaceRegexpOne(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1159, line 1162) (in query: SELECT replaceRegexpOne();) 2025.06.13 15:44:57.754485 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 0, should be 3: In scope SELECT replaceRegexpOne(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:57.761535 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiplyDecimal does not match: 2 or 3 expected: In scope SELECT multiplyDecimal(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:57.833758 [ 8431 ] {9998fe5c-4d1c-4e7b-8ab7-c37944631c4b} executeQuery: Code: 35. DB::Exception: Function replicate expect at least two arguments, got 0: In scope SELECT replicate(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1160, line 1163) (in query: SELECT replicate();) 2025.06.13 15:44:57.841317 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function replicate expect at least two arguments, got 0: In scope SELECT replicate(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:57.904875 [ 8431 ] {d7fd74f1-66c4-4dc6-9b99-7fe4dcf50a36} executeQuery: Code: 42. DB::Exception: Not enough event arguments for aggregate function retention. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1161, line 1164) (in query: SELECT retention();) 2025.06.13 15:44:57.920470 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Not enough event arguments for aggregate function retention. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:58.068565 [ 8431 ] {befc3dd8-6947-4a05-a0b0-7c67970fd987} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 0, should be 1: In scope SELECT reverse(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1162, line 1165) (in query: SELECT reverse();) 2025.06.13 15:44:58.078559 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 0, should be 1: In scope SELECT reverse(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:58.215301 [ 8431 ] {3fd01a64-95f5-46e1-be9a-bf59b02ca2e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 0, should be 1: In scope SELECT reverseUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1163, line 1166) (in query: SELECT reverseUTF8();) 2025.06.13 15:44:58.289612 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 0, should be 1: In scope SELECT reverseUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:58.688109 [ 8431 ] {508e61b7-ee28-4980-a468-b418c073b10d} executeQuery: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 0, should be 2: In scope SELECT right(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1165, line 1168) (in query: SELECT right();) 2025.06.13 15:44:58.701189 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 0, should be 2: In scope SELECT right(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:58.808102 [ 8431 ] {5412906b-4b8b-4767-a1ce-bd0f53514750} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 0, should be 2 or 3: In scope SELECT rightPad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1166, line 1169) (in query: SELECT rightPad();) 2025.06.13 15:44:58.819861 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 0, should be 2 or 3: In scope SELECT rightPad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:58.987858 [ 8431 ] {a7462c87-7d1e-46a5-ad1d-b0eb81ed8f04} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPadUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT rightPadUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1167, line 1170) (in query: SELECT rightPadUTF8();) 2025.06.13 15:44:59.024346 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPadUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT rightPadUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:59.212521 [ 5978 ] {9bee16c0-7128-491b-8324-e8b1a36d9e27} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 916, line 917) (in query: SELECT neighbor(-1);) 2025.06.13 15:44:59.222387 [ 5978 ] {} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:44:59.268321 [ 8431 ] {e168eb0a-363a-4dac-84a8-931e932b0e2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 0, should be 2: In scope SELECT rightUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1168, line 1171) (in query: SELECT rightUTF8();) 2025.06.13 15:44:59.294065 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 0, should be 2: In scope SELECT rightUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:59.365783 [ 5978 ] {df2286ed-b630-4a78-9bb8-cf344164044e} executeQuery: Code: 35. DB::Exception: Number of arguments for function nested doesn't match: passed 1, should be at least 2: In scope SELECT nested(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 917, line 918) (in query: SELECT nested(-1);) 2025.06.13 15:44:59.372342 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function nested doesn't match: passed 1, should be at least 2: In scope SELECT nested(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:44:59.378408 [ 8431 ] {4ad99fb7-b20f-4826-8ddb-f40b71594166} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'round'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT round(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1169, line 1172) (in query: SELECT round();) 2025.06.13 15:44:59.388071 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'round'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT round(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:59.439771 [ 8431 ] {61acbec2-8392-46a6-a324-fdc2d8f8a41a} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 0, should be 1: In scope SELECT roundAge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1170, line 1173) (in query: SELECT roundAge();) 2025.06.13 15:44:59.447101 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 0, should be 1: In scope SELECT roundAge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:59.448988 [ 5978 ] {4d586cfc-284f-4e9c-b439-cc299848712f} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function netloc: In scope SELECT netloc(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 918, line 919) (in query: SELECT netloc(-1);) 2025.06.13 15:44:59.470813 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function netloc: In scope SELECT netloc(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:44:59.546662 [ 8431 ] {c7064d53-d06c-4a95-881b-d22c857278fb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'roundBankers'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT roundBankers(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1171, line 1174) (in query: SELECT roundBankers();) 2025.06.13 15:44:59.559137 [ 5978 ] {04022ef6-a73e-4be5-8c5a-b4a84d05d4b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 1, should be 2: In scope SELECT ngramDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 919, line 920) (in query: SELECT ngramDistance(-1);) 2025.06.13 15:44:59.568231 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'roundBankers'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT roundBankers(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:59.580696 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 1, should be 2: In scope SELECT ngramDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:59.646974 [ 8431 ] {866aa3ab-1bd6-47b7-86c8-73f08cccc504} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 0, should be 2: In scope SELECT roundDown(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1172, line 1175) (in query: SELECT roundDown();) 2025.06.13 15:44:59.656101 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 0, should be 2: In scope SELECT roundDown(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:59.671357 [ 5978 ] {d1c9f518-deac-476d-bb9b-a5df19595088} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT ngramDistanceCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 920, line 921) (in query: SELECT ngramDistanceCaseInsensitive(-1);) 2025.06.13 15:44:59.684265 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT ngramDistanceCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:59.730880 [ 8431 ] {1e42ea75-2972-4b55-9c34-dbfd1df0286d} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 0, should be 1: In scope SELECT roundDuration(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1173, line 1176) (in query: SELECT roundDuration();) 2025.06.13 15:44:59.735747 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 0, should be 1: In scope SELECT roundDuration(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:59.820647 [ 5978 ] {3dea4a53-0232-4384-9bf8-0d093bc5733b} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 921, line 922) (in query: SELECT ngramDistanceCaseInsensitiveUTF8(-1);) 2025.06.13 15:44:59.824922 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:59.862095 [ 18377 ] {422066be-0cac-454f-9944-4da15de725e5} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54686) (comment: 02444_async_broken_outdated_part_loading.sh) (query 1, line 1) (in query: CREATE TABLE rmt (`n` int) ENGINE = ReplicatedMergeTree('/test/02444/02444_async_broken_outdated_part_loading_test_7/rmt', '1') ORDER BY n SETTINGS old_parts_lifetime = 600, index_granularity = 40695, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 25, min_bytes_for_full_part_storage = 508319127, compact_parts_max_bytes_to_buffer = 324127371, compact_parts_max_granules_to_buffer = 143, compact_parts_merge_max_bytes_to_prefetch_part = 4536676, merge_max_block_size = 42, 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 = 2029946866, index_granularity_bytes = 6863861, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 60, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 71104, primary_key_compress_block_size = 33482, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:44:59.887277 [ 18377 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:44:59.894636 [ 8431 ] {b38986ef-da64-469a-b2f4-4a46292ab6e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 0, should be 1: In scope SELECT roundToExp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1174, line 1177) (in query: SELECT roundToExp2();) 2025.06.13 15:44:59.906209 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 0, should be 1: In scope SELECT roundToExp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:44:59.945338 [ 5978 ] {5c183acc-33d2-4a22-89c2-68deaf6a2fb6} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramDistanceUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 922, line 923) (in query: SELECT ngramDistanceUTF8(-1);) 2025.06.13 15:44:59.964918 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramDistanceUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:00.115733 [ 5978 ] {451795d5-c28b-4190-8b46-45c26ad20d14} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHash must be String, got Int8: In scope SELECT ngramMinHash(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 923, line 924) (in query: SELECT ngramMinHash(-1);) 2025.06.13 15:45:00.172624 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHash must be String, got Int8: In scope SELECT ngramMinHash(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:00.395029 [ 5978 ] {af1f8024-891b-4c7a-832f-775d39326fa2} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArg must be String, got Int8: In scope SELECT ngramMinHashArg(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 924, line 925) (in query: SELECT ngramMinHashArg(-1);) 2025.06.13 15:45:00.422820 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArg must be String, got Int8: In scope SELECT ngramMinHashArg(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:00.466278 [ 8431 ] {738189c1-8019-42d6-8ee5-35dec9605b12} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1177, line 1180) (in query: SELECT row_number();) 2025.06.13 15:45:00.484626 [ 4171 ] {4a7952fb-e2dc-4c89-9eae-feb940177e6d} executeQuery: Code: 60. DB::Exception: Table test_7.rmt does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54732) (comment: 02444_async_broken_outdated_part_loading.sh) (query 1, line 1) (in query: insert into rmt values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:00.522431 [ 4171 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.rmt does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:00.538593 [ 5978 ] {f96c4ed0-aef4-4256-8183-61861130c574} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitive must be String, got Int8: In scope SELECT ngramMinHashArgCaseInsensitive(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 925, line 926) (in query: SELECT ngramMinHashArgCaseInsensitive(-1);) 2025.06.13 15:45:00.558402 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitive must be String, got Int8: In scope SELECT ngramMinHashArgCaseInsensitive(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:00.599461 [ 8431 ] {} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:45:00.739759 [ 8431 ] {f184a475-e3d8-410c-8da0-b36da38f01d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 0, should be 2 or 3: In scope SELECT rpad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1178, line 1181) (in query: SELECT rpad();) 2025.06.13 15:45:00.779648 [ 5978 ] {a404c316-b9b1-4b3b-be45-706b4f5fc366} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitiveUTF8 must be String, got Int8: In scope SELECT ngramMinHashArgCaseInsensitiveUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 926, line 927) (in query: SELECT ngramMinHashArgCaseInsensitiveUTF8(-1);) 2025.06.13 15:45:00.784109 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 0, should be 2 or 3: In scope SELECT rpad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:00.785497 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitiveUTF8 must be String, got Int8: In scope SELECT ngramMinHashArgCaseInsensitiveUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:00.873765 [ 5978 ] {a11039c2-ee8a-4f5a-ad30-69b981514284} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgUTF8 must be String, got Int8: In scope SELECT ngramMinHashArgUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 927, line 928) (in query: SELECT ngramMinHashArgUTF8(-1);) 2025.06.13 15:45:00.878552 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgUTF8 must be String, got Int8: In scope SELECT ngramMinHashArgUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:00.886165 [ 8431 ] {f96f8aa4-cb8a-43b7-8135-04ea5e96348e} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1179, line 1183) (in query: SELECT runningAccumulate();) 2025.06.13 15:45:00.900835 [ 8431 ] {} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:45:01.044763 [ 5978 ] {dc7dae6b-787c-4705-9d6c-3de02419fba2} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitive must be String, got Int8: In scope SELECT ngramMinHashCaseInsensitive(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 928, line 929) (in query: SELECT ngramMinHashCaseInsensitive(-1);) 2025.06.13 15:45:01.054614 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitive must be String, got Int8: In scope SELECT ngramMinHashCaseInsensitive(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:01.057675 [ 8431 ] {eb75feaa-5e3a-4d6a-8705-2bf25a4f1e1f} executeQuery: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 0, should be 2: In scope SELECT runningConcurrency(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1180, line 1184) (in query: SELECT runningConcurrency();) 2025.06.13 15:45:01.086302 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 0, should be 2: In scope SELECT runningConcurrency(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:01.185150 [ 5978 ] {78adc89e-76c2-4a19-b9e2-0383875a6d6e} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitiveUTF8 must be String, got Int8: In scope SELECT ngramMinHashCaseInsensitiveUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 929, line 930) (in query: SELECT ngramMinHashCaseInsensitiveUTF8(-1);) 2025.06.13 15:45:01.197487 [ 7755 ] {e687861e-9844-4618-907c-cda89a807064} executeQuery: Code: 60. DB::Exception: Table test_7.rmt does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54792) (comment: 02444_async_broken_outdated_part_loading.sh) (query 1, line 1) (in query: insert into rmt values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:01.202800 [ 8431 ] {f971e300-c67d-4c63-bbb1-e0d8480455bc} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1181, line 1185) (in query: SELECT runningDifference();) 2025.06.13 15:45:01.210554 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitiveUTF8 must be String, got Int8: In scope SELECT ngramMinHashCaseInsensitiveUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:01.217565 [ 8431 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:45:01.255980 [ 7755 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.rmt does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:01.308704 [ 8431 ] {3d1b4084-cab1-45e9-abe7-0efa4a608f08} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1182, line 1186) (in query: SELECT runningDifferenceStartingWithFirstValue();) 2025.06.13 15:45:01.312748 [ 5978 ] {9b232e62-029c-4957-80fa-1f7a9ce50b7f} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashUTF8 must be String, got Int8: In scope SELECT ngramMinHashUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 930, line 931) (in query: SELECT ngramMinHashUTF8(-1);) 2025.06.13 15:45:01.317854 [ 8431 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:45:01.345482 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashUTF8 must be String, got Int8: In scope SELECT ngramMinHashUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:01.522078 [ 8431 ] {ce9bde66-7745-4886-8999-de1e9b9515b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 0, should be 3: In scope SELECT s2CapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1183, line 1187) (in query: SELECT s2CapContains();) 2025.06.13 15:45:01.525023 [ 5978 ] {60db1d34-d94c-4f88-bcfe-dd8dfbe51c7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 1, should be 2: In scope SELECT ngramSearch(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 931, line 932) (in query: SELECT ngramSearch(-1);) 2025.06.13 15:45:01.543001 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 0, should be 3: In scope SELECT s2CapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:01.543543 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 1, should be 2: In scope SELECT ngramSearch(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:01.590802 [ 5978 ] {184fedd2-c85a-442f-8964-c222c010c57b} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT ngramSearchCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 932, line 933) (in query: SELECT ngramSearchCaseInsensitive(-1);) 2025.06.13 15:45:01.604749 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 1, should be 2: In scope SELECT ngramSearchCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:01.617045 [ 8431 ] {af258101-24dd-4c79-b4da-797f5d9091ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 0, should be 4: In scope SELECT s2CapUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1184, line 1188) (in query: SELECT s2CapUnion();) 2025.06.13 15:45:01.640844 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 0, should be 4: In scope SELECT s2CapUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:01.711039 [ 5978 ] {bb1df6ca-fe27-455e-a225-2bcb7be87e8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 933, line 934) (in query: SELECT ngramSearchCaseInsensitiveUTF8(-1);) 2025.06.13 15:45:01.716025 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:01.798295 [ 8431 ] {e272ddb8-9828-4576-b9cd-68fdb41534bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 0, should be 2: In scope SELECT s2CellsIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1185, line 1189) (in query: SELECT s2CellsIntersect();) 2025.06.13 15:45:01.809796 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 0, should be 2: In scope SELECT s2CellsIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:01.852011 [ 5978 ] {1a168a4a-d21b-4b91-aaa2-b004f7cd5d8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramSearchUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 934, line 935) (in query: SELECT ngramSearchUTF8(-1);) 2025.06.13 15:45:01.854491 [ 18602 ] {70ecf177-e536-4be8-b591-0bb6562d228c} executeQuery: Code: 60. DB::Exception: Table test_7.rmt does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54818) (comment: 02444_async_broken_outdated_part_loading.sh) (query 1, line 1) (in query: system sync replica rmt pull;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1282: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000002e30059b 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x000000002e2ec877 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:01.876408 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 1, should be 2: In scope SELECT ngramSearchUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:01.889836 [ 18602 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.rmt does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1282: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000002e30059b 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x000000002e2ec877 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:01.979133 [ 8431 ] {da0646fa-159e-4210-84d2-07d3a8faacb8} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 0, should be 1: In scope SELECT s2GetNeighbors(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1186, line 1190) (in query: SELECT s2GetNeighbors();) 2025.06.13 15:45:02.009548 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 0, should be 1: In scope SELECT s2GetNeighbors(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:02.076029 [ 5978 ] {d3d426f9-6ee4-4554-a54e-72a16fee3524} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHash must be String, got Int8: In scope SELECT ngramSimHash(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 935, line 936) (in query: SELECT ngramSimHash(-1);) 2025.06.13 15:45:02.081715 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHash must be String, got Int8: In scope SELECT ngramSimHash(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:02.122403 [ 8431 ] {bfad9ba2-e392-4cae-85ac-e67eb60be1dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 0, should be 3: In scope SELECT s2RectAdd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1187, line 1191) (in query: SELECT s2RectAdd();) 2025.06.13 15:45:02.137329 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 0, should be 3: In scope SELECT s2RectAdd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:02.142315 [ 7755 ] {3bb49603-07b5-407b-8ac8-3a42f9b2689c} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54834) (comment: 01042_system_reload_dictionary_reloads_completely.sh) (query 1, line 1) (in query: CREATE TABLE test_11.table(x Int64, y Int64, insert_time DateTime) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:02.178600 [ 7755 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:02.189537 [ 5978 ] {0b5724f8-7aa2-41f7-8f2c-f1bac1b6b2b1} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitive must be String, got Int8: In scope SELECT ngramSimHashCaseInsensitive(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 936, line 937) (in query: SELECT ngramSimHashCaseInsensitive(-1);) 2025.06.13 15:45:02.262211 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitive must be String, got Int8: In scope SELECT ngramSimHashCaseInsensitive(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:02.287159 [ 8431 ] {2c4a95c0-282b-490b-9c67-f61dc1f9af87} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 0, should be 3: In scope SELECT s2RectContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1188, line 1192) (in query: SELECT s2RectContains();) 2025.06.13 15:45:02.300948 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 0, should be 3: In scope SELECT s2RectContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:02.337649 [ 5978 ] {77cdfba0-d05f-42d7-921e-a984368039d2} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitiveUTF8 must be String, got Int8: In scope SELECT ngramSimHashCaseInsensitiveUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 937, line 938) (in query: SELECT ngramSimHashCaseInsensitiveUTF8(-1);) 2025.06.13 15:45:02.366586 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitiveUTF8 must be String, got Int8: In scope SELECT ngramSimHashCaseInsensitiveUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:02.465460 [ 8431 ] {5ac73599-61b5-414e-a377-1454fd17fabd} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 0, should be 4: In scope SELECT s2RectIntersection(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1189, line 1193) (in query: SELECT s2RectIntersection();) 2025.06.13 15:45:02.478641 [ 5978 ] {5ed0f126-7e29-4274-8264-ca760a2e4a22} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashUTF8 must be String, got Int8: In scope SELECT ngramSimHashUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 938, line 939) (in query: SELECT ngramSimHashUTF8(-1);) 2025.06.13 15:45:02.500909 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashUTF8 must be String, got Int8: In scope SELECT ngramSimHashUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:02.537221 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 0, should be 4: In scope SELECT s2RectIntersection(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:02.593877 [ 9642 ] {2f9c6627-a86a-4e28-831b-ad848b64bb26} executeQuery: Code: 60. DB::Exception: Table test_7.rmt does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54842) (comment: 02444_async_broken_outdated_part_loading.sh) (query 1, line 1) (in query: optimize table rmt final), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e32573d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:45:02.613710 [ 9642 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.rmt does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e32573d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:45:02.654472 [ 8442 ] {6c078174-d49c-4b4d-84eb-6ccfc25e9c82} executeQuery: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; S. . (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53382) (comment: 00366_multi_statements.sh) (in query: SELECT 1; S), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:45:02.661334 [ 8442 ] {6c078174-d49c-4b4d-84eb-6ccfc25e9c82} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; S. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:45:02.670754 [ 5978 ] {365fdc33-e954-4a10-9a70-6ad3a249ed95} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 1, should be 2: In scope SELECT ngrams(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 939, line 940) (in query: SELECT ngrams(-1);) 2025.06.13 15:45:02.676295 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 1, should be 2: In scope SELECT ngrams(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:02.700766 [ 8431 ] {b2c74a2b-bf8a-4e8b-91be-a6f4ce8d1515} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 0, should be 4: In scope SELECT s2RectUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1190, line 1194) (in query: SELECT s2RectUnion();) 2025.06.13 15:45:02.714373 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 0, should be 4: In scope SELECT s2RectUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:02.794791 [ 5978 ] {750f3b73-fc4b-48d5-9030-05415db7ab04} executeQuery: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 940, line 941) (in query: SELECT nonNegativeDerivative(-1);) 2025.06.13 15:45:02.834833 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:02.846166 [ 8431 ] {8a21ea92-b223-4f44-a573-025975ee71e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 0, should be 1: In scope SELECT s2ToGeo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1191, line 1195) (in query: SELECT s2ToGeo();) 2025.06.13 15:45:02.853876 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 0, should be 1: In scope SELECT s2ToGeo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:02.868598 [ 9642 ] {147520c2-f8d9-46f6-8a2a-d44b93646f5c} executeQuery: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2. . (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53396) (comment: 00366_multi_statements.sh) (in query: SELECT 1; SELECT 2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:45:02.870052 [ 9642 ] {147520c2-f8d9-46f6-8a2a-d44b93646f5c} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:45:02.881952 [ 5978 ] {9c545c13-9df1-4c99-b155-908fa3177d7f} executeQuery: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got Int8: In scope SELECT normL1(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 941, line 942) (in query: SELECT normL1(-1);) 2025.06.13 15:45:02.888157 [ 9644 ] {5113c3ca-0b6a-4978-b644-1b5ed3e2011d} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54858) (comment: 01710_normal_projection_fix1.sql) (query 2, line 3) (in query: CREATE TABLE t (`i` int, `j` int) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 29133, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.00408781785517931, replace_long_file_name_to_hash = false, max_file_name_length = 121, min_bytes_for_full_part_storage = 51372891, compact_parts_max_bytes_to_buffer = 394481418, compact_parts_max_granules_to_buffer = 127, compact_parts_merge_max_bytes_to_prefetch_part = 13064218, merge_max_block_size = 8586, old_parts_lifetime = 146., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 38926, vertical_merge_algorithm_min_columns_to_activate = 59, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 22242389, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 20597, primary_key_compress_block_size = 14414, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:02.890667 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got Int8: In scope SELECT normL1(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:02.899885 [ 9644 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:02.986731 [ 8431 ] {2f0ec335-3e40-4798-ae0a-fc1d30f5f833} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 0, should be 2: In scope SELECT scalarProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1192, line 1196) (in query: SELECT scalarProduct();) 2025.06.13 15:45:02.994812 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 0, should be 2: In scope SELECT scalarProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:03.031246 [ 8442 ] {bb81ece5-5e00-49f9-af16-cb330af1a1e4} executeQuery: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2;. . (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53410) (comment: 00366_multi_statements.sh) (in query: SELECT 1; SELECT 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:45:03.033028 [ 8442 ] {bb81ece5-5e00-49f9-af16-cb330af1a1e4} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2;. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:45:03.051925 [ 5978 ] {342ef653-ecb0-4705-86a6-9a3c5a3856c9} executeQuery: Code: 43. DB::Exception: Argument 0 of function L2Norm should be tuple, got Int8: In scope SELECT normL2(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 942, line 943) (in query: SELECT normL2(-1);) 2025.06.13 15:45:03.074619 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L2Norm should be tuple, got Int8: In scope SELECT normL2(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:03.215603 [ 8431 ] {84ac287c-4c07-44cc-bdeb-758bf9d3413d} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1193, line 1197) (in query: SELECT sequenceCount();) 2025.06.13 15:45:03.222556 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:03.239594 [ 5978 ] {bd0760e5-c1cb-49bf-9439-1a3f661acf84} executeQuery: Code: 43. DB::Exception: Argument 0 of function L2SquaredNorm should be tuple, got Int8: In scope SELECT normL2Squared(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 943, line 944) (in query: SELECT normL2Squared(-1);) 2025.06.13 15:45:03.250021 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L2SquaredNorm should be tuple, got Int8: In scope SELECT normL2Squared(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:03.276359 [ 9644 ] {2ab712e0-55ea-426b-b929-45a948193e05} executeQuery: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2; SELECT. . (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:52386) (comment: 00366_multi_statements.sh) (in query: SELECT 1; SELECT 2; SELECT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:45:03.279335 [ 9644 ] {2ab712e0-55ea-426b-b929-45a948193e05} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2; SELECT. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:45:03.335943 [ 8431 ] {42017fd5-a454-438f-874d-abc98fdd200f} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1194, line 1198) (in query: SELECT sequenceMatch();) 2025.06.13 15:45:03.346512 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:03.430425 [ 8431 ] {3cc309a1-a055-42e5-9953-4ea7535d274c} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceMatchEvents requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1195, line 1199) (in query: SELECT sequenceMatchEvents();) 2025.06.13 15:45:03.432456 [ 5978 ] {3fde24de-612a-41a5-be0c-3f6b5c6028d2} executeQuery: Code: 43. DB::Exception: Argument 0 of function LinfNorm should be tuple, got Int8: In scope SELECT normLinf(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 944, line 945) (in query: SELECT normLinf(-1);) 2025.06.13 15:45:03.433514 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceMatchEvents requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:03.436400 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function LinfNorm should be tuple, got Int8: In scope SELECT normLinf(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:03.441015 [ 9642 ] {07e3161b-838d-4a54-a53f-83b107cfef52} executeQuery: Code: 60. DB::Exception: Table test_7.rmt does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54868) (comment: 02444_async_broken_outdated_part_loading.sh) (query 1, line 1) (in query: system sync replica rmt;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1282: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000002e30059b 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x000000002e2ec877 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:03.461748 [ 9642 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.rmt does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1282: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000002e30059b 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:763: DB::InterpreterSystemQuery::execute() @ 0x000000002e2ec877 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:03.482883 [ 5978 ] {47bcb7b7-b52b-4424-aa0e-93f730ff839e} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 1, should be 2: In scope SELECT normLp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 945, line 946) (in query: SELECT normLp(-1);) 2025.06.13 15:45:03.487564 [ 8431 ] {4c0996c1-c6bf-4b60-8262-5e93cae3663c} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1196, line 1200) (in query: SELECT sequenceNextNode();) 2025.06.13 15:45:03.489022 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 1, should be 2: In scope SELECT normLp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:03.497292 [ 8431 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.06.13 15:45:03.561005 [ 5978 ] {a36ee6fb-0d6f-41e0-9670-66cb8eda69b5} executeQuery: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got Int8: In scope SELECT normalizeL1(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 946, line 947) (in query: SELECT normalizeL1(-1);) 2025.06.13 15:45:03.566556 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got Int8: In scope SELECT normalizeL1(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:03.593133 [ 8431 ] {dac0f63f-f93c-4afc-a447-f4f9357fb9d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 0, should be 2: In scope SELECT seriesDecomposeSTL(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1197, line 1201) (in query: SELECT seriesDecomposeSTL();) 2025.06.13 15:45:03.617218 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 0, should be 2: In scope SELECT seriesDecomposeSTL(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:03.639312 [ 5978 ] {6e66340c-c3c8-4f3b-922d-dc933a1d8e3e} executeQuery: Code: 43. DB::Exception: Argument 0 of function L2Norm should be tuple, got Int8: In scope SELECT normalizeL2(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 947, line 948) (in query: SELECT normalizeL2(-1);) 2025.06.13 15:45:03.647932 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L2Norm should be tuple, got Int8: In scope SELECT normalizeL2(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:03.663450 [ 18510 ] {cf0596c6-19f0-41cd-9bd4-e098424c0a9a} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41690) (comment: 03364_gorilla_codec_parameters.sql) (query 2, line 2) (in query: CREATE TABLE `03364_gorilla` (`c0` String CODEC(Gorilla(1))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 38386, min_bytes_for_wide_part = 460404641, ratio_of_defaults_for_sparse_serialization = 0.4160271883010864, replace_long_file_name_to_hash = false, max_file_name_length = 127, min_bytes_for_full_part_storage = 336809171, compact_parts_max_bytes_to_buffer = 239980317, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 3247073, merge_max_block_size = 24180, old_parts_lifetime = 48., prefer_fetch_merged_part_size_threshold = 5713759073, vertical_merge_algorithm_min_rows_to_activate = 795245, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8804598594, index_granularity_bytes = 22047178, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 82377, primary_key_compress_block_size = 63704, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:03.676399 [ 18510 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:03.719058 [ 8431 ] {5b870089-e19a-46af-bd39-85cf95520db5} executeQuery: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 0.: In scope SELECT seriesOutliersDetectTukey(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1198, line 1202) (in query: SELECT seriesOutliersDetectTukey();) 2025.06.13 15:45:03.722720 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 0.: In scope SELECT seriesOutliersDetectTukey(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:03.761592 [ 5978 ] {d5e5441b-e929-409a-b94e-07a2a96d0c27} executeQuery: Code: 43. DB::Exception: Argument 0 of function LinfNorm should be tuple, got Int8: In scope SELECT normalizeLinf(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 948, line 949) (in query: SELECT normalizeLinf(-1);) 2025.06.13 15:45:03.766656 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function LinfNorm should be tuple, got Int8: In scope SELECT normalizeLinf(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:03.819172 [ 8431 ] {7a8e6cb4-484b-4e1b-a2ed-2b5fe8bd454c} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 0, should be 1: In scope SELECT seriesPeriodDetectFFT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1199, line 1203) (in query: SELECT seriesPeriodDetectFFT();) 2025.06.13 15:45:03.832329 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 0, should be 1: In scope SELECT seriesPeriodDetectFFT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:03.947060 [ 5978 ] {3adbdb7f-b894-414d-a9d0-7dff9c18c9eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 1, should be 2: In scope SELECT normalizeLp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 949, line 950) (in query: SELECT normalizeLp(-1);) 2025.06.13 15:45:03.952102 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 1, should be 2: In scope SELECT normalizeLp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:03.989098 [ 18510 ] {e4115f4b-af14-4b49-867b-92ffcc8a6c71} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'rmt' in scope SELECT 1, *, _part FROM rmt ORDER BY n ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41716) (comment: 02444_async_broken_outdated_part_loading.sh) (query 1, line 1) (in query: select 1, *, _part from rmt order by n;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:45:04.015921 [ 18510 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'rmt' in scope SELECT 1, *, _part FROM rmt ORDER BY n ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:45:04.072450 [ 5978 ] {b96df88b-761b-4c0a-ae41-483053b9c5d8} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizeQuery: In scope SELECT normalizeQuery(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 950, line 951) (in query: SELECT normalizeQuery(-1);) 2025.06.13 15:45:04.101704 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizeQuery: In scope SELECT normalizeQuery(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:04.368546 [ 5978 ] {d8abb314-2bea-4d18-8564-3a262142a3cb} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizeQueryKeepNames: In scope SELECT normalizeQueryKeepNames(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 951, line 952) (in query: SELECT normalizeQueryKeepNames(-1);) 2025.06.13 15:45:04.386605 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizeQueryKeepNames: In scope SELECT normalizeQueryKeepNames(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:04.559601 [ 5978 ] {ebbb175d-e4e3-4606-82c0-a8b7c356e80b} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizeUTF8NFC: In scope SELECT normalizeUTF8NFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 952, line 953) (in query: SELECT normalizeUTF8NFC(-1);) 2025.06.13 15:45:04.566857 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizeUTF8NFC: In scope SELECT normalizeUTF8NFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:04.688917 [ 5978 ] {54dd09d0-71b2-4ddd-b4af-7031fd9efa3b} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizeUTF8NFD: In scope SELECT normalizeUTF8NFD(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 953, line 954) (in query: SELECT normalizeUTF8NFD(-1);) 2025.06.13 15:45:04.699425 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizeUTF8NFD: In scope SELECT normalizeUTF8NFD(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:04.793467 [ 3894 ] {0d4e11a6-a8ae-4424-be7d-b01ed018bc0b} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41746) (comment: 01144_multiword_data_types.sql) (query 3, line 4) (in query: CREATE TABLE multiword_types ( a DOUBLE, b DOUBLE PRECISION, c CHAR DEFAULT 'str', d CHAR VARYING, e CHAR LARGE OBJECT COMMENT 'comment', f CHARACTER VARYING(123), g ChArAcTeR large OBJECT, h nchar varying (456) default toString(a) comment 'comment', i NCHAR LARGE OBJECT, j BINARY LARGE OBJECT, k BINARY VARYING, l NATIONAL CHAR, m NATIONAL CHARACTER, n NATIONAL CHARACTER LARGE OBJECT, o NATIONAL CHARACTER VARYING, p NATIONAL CHAR VARYING ) ENGINE=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:04.808866 [ 3894 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:04.882153 [ 5978 ] {9d2f1ad5-3adf-40a1-a90b-98981ac85d0c} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizeUTF8NFKC: In scope SELECT normalizeUTF8NFKC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 954, line 955) (in query: SELECT normalizeUTF8NFKC(-1);) 2025.06.13 15:45:04.887692 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizeUTF8NFKC: In scope SELECT normalizeUTF8NFKC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:05.001207 [ 5978 ] {490011d5-1533-4704-9b28-22081f9374b8} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizeUTF8NFKD: In scope SELECT normalizeUTF8NFKD(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 955, line 956) (in query: SELECT normalizeUTF8NFKD(-1);) 2025.06.13 15:45:05.013642 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizeUTF8NFKD: In scope SELECT normalizeUTF8NFKD(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:05.084271 [ 5978 ] {a9420a6f-98d6-4a20-b973-c850fa1f54df} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizedQueryHash: In scope SELECT normalizedQueryHash(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 956, line 957) (in query: SELECT normalizedQueryHash(-1);) 2025.06.13 15:45:05.116001 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizedQueryHash: In scope SELECT normalizedQueryHash(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:05.180823 [ 8431 ] {f5257e7e-db04-43f7-8259-c036fb333443} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 0, should be 1: In scope SELECT sigmoid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1206, line 1210) (in query: SELECT sigmoid();) 2025.06.13 15:45:05.185661 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 0, should be 1: In scope SELECT sigmoid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:05.212547 [ 5978 ] {13f25a78-6e25-4ec0-8560-bdb0b40d25b9} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizedQueryHashKeepNames: In scope SELECT normalizedQueryHashKeepNames(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 957, line 958) (in query: SELECT normalizedQueryHashKeepNames(-1);) 2025.06.13 15:45:05.232803 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function normalizedQueryHashKeepNames: In scope SELECT normalizedQueryHashKeepNames(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:05.262044 [ 8431 ] {4902f724-9f44-4ede-9416-95c2180eb396} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 0, should be 1: In scope SELECT sign(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1207, line 1211) (in query: SELECT sign();) 2025.06.13 15:45:05.282651 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 0, should be 1: In scope SELECT sign(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:05.313232 [ 7755 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:05.318323 [ 7755 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:45:05.361236 [ 8431 ] {3756eaf7-dc64-4ffb-ae23-29776ac16daf} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1208, line 1212) (in query: SELECT simpleJSONExtractBool();) 2025.06.13 15:45:05.365928 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:05.425680 [ 18511 ] {b817b18c-873d-47e1-a354-4652d4c1a549} executeQuery: Code: 395. DB::Exception: Path is relative: : while executing 'FUNCTION throwIf(_CAST(1_UInt8, 'UInt8'_String) :: 1, 'Path is relative: '_String :: 2) -> throwIf(_CAST(1_UInt8, 'UInt8'_String), 'Path is relative: '_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41800) (comment: 02444_async_broken_outdated_part_loading.sh) (query 1, line 1) (in query: select throwIf(substring('', 1, 1) != '/', 'Path is relative: ')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createRuntime(int, String const&) @ 0x0000000020a7f1ff 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c0b0 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:45:05.519977 [ 8431 ] {c08edaf1-de9e-4779-b2fb-e2db0a8ef9b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1209, line 1213) (in query: SELECT simpleJSONExtractFloat();) 2025.06.13 15:45:05.521523 [ 18511 ] {} TCPHandler: Code: 395. DB::Exception: Path is relative: : while executing 'FUNCTION throwIf(_CAST(1_UInt8, 'UInt8'_String) :: 1, 'Path is relative: '_String :: 2) -> throwIf(_CAST(1_UInt8, 'UInt8'_String), 'Path is relative: '_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createRuntime(int, String const&) @ 0x0000000020a7f1ff 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c0b0 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:45:05.526482 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:05.562765 [ 5978 ] {3e05525d-4c58-474c-9275-b3429fbd50a6} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function notEmpty: In scope SELECT notEmpty(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 959, line 960) (in query: SELECT notEmpty(-1);) 2025.06.13 15:45:05.574411 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function notEmpty: In scope SELECT notEmpty(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:05.647078 [ 8431 ] {616f1faa-541b-4292-b099-05d45232d594} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1210, line 1214) (in query: SELECT simpleJSONExtractInt();) 2025.06.13 15:45:05.652664 [ 5978 ] {b207b115-d7fd-4aa2-9a54-071aa725dd98} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 1, should be 2: In scope SELECT notEquals(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 960, line 961) (in query: SELECT notEquals(-1);) 2025.06.13 15:45:05.653238 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:05.660474 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 1, should be 2: In scope SELECT notEquals(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:05.738866 [ 8431 ] {e6a870df-e78f-4b9d-99cc-3f74f9289440} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1211, line 1215) (in query: SELECT simpleJSONExtractRaw();) 2025.06.13 15:45:05.746516 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:05.750005 [ 5978 ] {6316b1c2-8fe0-47d9-bc7a-2938827ee19e} executeQuery: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 1, should be 2: In scope SELECT notILike(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 961, line 962) (in query: SELECT notILike(-1);) 2025.06.13 15:45:05.768188 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 1, should be 2: In scope SELECT notILike(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:05.855475 [ 8431 ] {ef280f9d-1e35-498f-960a-a6f6c1b5d319} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1212, line 1216) (in query: SELECT simpleJSONExtractString();) 2025.06.13 15:45:05.873176 [ 5978 ] {4ab78998-6bdb-475c-82e8-5968a066779f} executeQuery: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 962, line 963) (in query: SELECT notIn(-1);) 2025.06.13 15:45:05.891285 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:05.894569 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:05.961816 [ 8431 ] {b996e519-1aca-4cab-8bd7-a5ca18336895} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1213, line 1217) (in query: SELECT simpleJSONExtractUInt();) 2025.06.13 15:45:05.968164 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:05.968590 [ 5978 ] {b0584c45-7d48-4042-a6e8-fc84c3288dd3} executeQuery: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 963, line 964) (in query: SELECT notInIgnoreSet(-1);) 2025.06.13 15:45:06.033116 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:06.057969 [ 8431 ] {6490b8ec-9913-40b4-b0a4-04b2cdfce9a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 0, should be 2: In scope SELECT simpleJSONHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1214, line 1218) (in query: SELECT simpleJSONHas();) 2025.06.13 15:45:06.074833 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 0, should be 2: In scope SELECT simpleJSONHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:06.075181 [ 5978 ] {f447ba37-54cc-45c0-9b12-d0b4314d88fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 1, should be 2: In scope SELECT notLike(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 964, line 965) (in query: SELECT notLike(-1);) 2025.06.13 15:45:06.095188 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 1, should be 2: In scope SELECT notLike(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:06.175215 [ 8431 ] {3783cf18-1a73-4dc7-91f2-30a59fe2c2c7} executeQuery: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1215, line 1219) (in query: SELECT simpleLinearRegression();) 2025.06.13 15:45:06.181534 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:06.272175 [ 8431 ] {40668b6c-ead4-474a-be78-16184bb5a001} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 0, should be 1: In scope SELECT sin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1216, line 1220) (in query: SELECT sin();) 2025.06.13 15:45:06.280626 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 0, should be 1: In scope SELECT sin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:06.329002 [ 5978 ] {b3027eb7-d49c-448c-bb9d-2ee269aa082e} executeQuery: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 965, line 966) (in query: SELECT notNullIn(-1);) 2025.06.13 15:45:06.333323 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:06.353769 [ 8431 ] {0b7a57e1-6277-446c-91dc-278ca9f437f5} executeQuery: Code: 42. DB::Exception: Aggregate function singleValueOrNull requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1217, line 1221) (in query: SELECT singleValueOrNull();) 2025.06.13 15:45:06.364648 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function singleValueOrNull requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:06.382086 [ 5978 ] {f4e5a840-43b5-45cf-ae56-e85dee0240f2} executeQuery: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 966, line 967) (in query: SELECT notNullInIgnoreSet(-1);) 2025.06.13 15:45:06.414458 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:06.517206 [ 8431 ] {9a606c6c-010c-4ff8-9187-6cbb22ffd23e} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 0, should be 1: In scope SELECT sinh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1218, line 1222) (in query: SELECT sinh();) 2025.06.13 15:45:06.525316 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 0, should be 1: In scope SELECT sinh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:07.173235 [ 5978 ] {e57a848e-f5b0-4313-868a-efc6ad0fa274} executeQuery: Code: 43. DB::Exception: Arguments of function now should be String or FixedString: In scope SELECT now(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 970, line 971) (in query: SELECT now(-1);) 2025.06.13 15:45:07.187053 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function now should be String or FixedString: In scope SELECT now(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:07.295414 [ 5978 ] {26d93634-1abc-4aaa-acff-1a17508faa7b} executeQuery: Code: 69. DB::Exception: Scale 255 is out of bounds (max scale: 18): In scope SELECT now64(-1). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 971, line 972) (in query: SELECT now64(-1);) 2025.06.13 15:45:07.322511 [ 5978 ] {} TCPHandler: Code: 69. DB::Exception: Scale 255 is out of bounds (max scale: 18): In scope SELECT now64(-1). (ARGUMENT_OUT_OF_BOUND) 2025.06.13 15:45:07.426161 [ 5978 ] {b74c9412-7b5c-415d-8779-cd4649832818} executeQuery: Code: 43. DB::Exception: Arguments of function nowInBlock should be String or FixedString: In scope SELECT nowInBlock(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 972, line 973) (in query: SELECT nowInBlock(-1);) 2025.06.13 15:45:07.456174 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function nowInBlock should be String or FixedString: In scope SELECT nowInBlock(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:07.538669 [ 5978 ] {6ba0573a-af16-4a6e-9356-5a2cff000b06} executeQuery: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 973, line 974) (in query: SELECT nth_value(-1);) 2025.06.13 15:45:07.546727 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:07.595696 [ 18377 ] {cc2f8dda-5a60-4dc4-a2fa-10d0fab3af8a} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54748) (comment: 02498_storage_join_key_positions.sql) (query 26, line 38) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Planner/PlannerJoinsLogical.cpp:529: DB::buildJoinStepLogical(DB::Block const&, DB::Block const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x000000002ddd9d9d 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2060: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9829e 7. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:07.634945 [ 18377 ] {} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Planner/PlannerJoinsLogical.cpp:529: DB::buildJoinStepLogical(DB::Block const&, DB::Block const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x000000002ddd9d9d 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2060: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9829e 7. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:07.649450 [ 5978 ] {7c6d4889-2beb-462e-9b2f-30e4e4fc7e67} executeQuery: Code: 36. DB::Exception: 'ntile' argument type must be an unsigned integer (not larger than 64-bit), got Int8. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 974, line 975) (in query: SELECT ntile(-1);) 2025.06.13 15:45:07.649522 [ 8431 ] {d45cde78-b376-49ba-b11f-9c26ac80ae4f} executeQuery: Code: 42. DB::Exception: Aggregate function skewPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1225, line 1229) (in query: SELECT skewPop();) 2025.06.13 15:45:07.655763 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: 'ntile' argument type must be an unsigned integer (not larger than 64-bit), got Int8. (BAD_ARGUMENTS) 2025.06.13 15:45:07.656128 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function skewPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:07.744331 [ 8431 ] {b2a6c12d-d288-4966-b31b-1c43870700a9} executeQuery: Code: 42. DB::Exception: Aggregate function skewSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1226, line 1230) (in query: SELECT skewSamp();) 2025.06.13 15:45:07.750533 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function skewSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:07.758819 [ 5978 ] {4defb2c9-5919-4e7a-bb66-f4869c9fdd8a} executeQuery: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 1, should be 2: In scope SELECT nullIf(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 975, line 976) (in query: SELECT nullIf(-1);) 2025.06.13 15:45:07.763546 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 1, should be 2: In scope SELECT nullIf(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:07.942447 [ 5978 ] {a3a009a5-2b54-4d70-aef2-707d5a71d5b8} executeQuery: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 976, line 977) (in query: SELECT nullIn(-1);) 2025.06.13 15:45:07.942994 [ 8431 ] {45da5ebb-6be4-479b-9143-9f2d140fc79e} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 0, should be 1: In scope SELECT sleep(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1227, line 1231) (in query: SELECT sleep();) 2025.06.13 15:45:07.955661 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 0, should be 1: In scope SELECT sleep(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:07.959641 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:08.051558 [ 5978 ] {07511c0d-8312-4d5d-9b4f-9601fd61ef92} executeQuery: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 977, line 978) (in query: SELECT nullInIgnoreSet(-1);) 2025.06.13 15:45:08.060335 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:08.104622 [ 8431 ] {2152e330-fbc3-4b92-8d75-51831c97a10b} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 0, should be 1: In scope SELECT sleepEachRow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1228, line 1232) (in query: SELECT sleepEachRow();) 2025.06.13 15:45:08.125361 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 0, should be 1: In scope SELECT sleepEachRow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:08.163908 [ 5978 ] {03f96b39-3b66-42cc-bd71-704f923b0703} executeQuery: Code: 35. DB::Exception: Number of arguments for function "or" should be at least 2: passed 1: In scope SELECT or(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 978, line 979) (in query: SELECT or(-1);) 2025.06.13 15:45:08.181433 [ 8431 ] {c01a8f34-600c-45e9-a010-96041cb53c49} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1229, line 1233) (in query: SELECT snowflakeIDToDateTime();) 2025.06.13 15:45:08.184979 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "or" should be at least 2: passed 1: In scope SELECT or(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:45:08.203283 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:08.304004 [ 8431 ] {9a65cf41-8049-44d2-8fe3-1c02b01f6996} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1230, line 1234) (in query: SELECT snowflakeIDToDateTime64();) 2025.06.13 15:45:08.321760 [ 5978 ] {bb371f1f-975f-49af-89d9-95400bac5423} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlay'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT overlay(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 979, line 980) (in query: SELECT overlay(-1);) 2025.06.13 15:45:08.323587 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:08.327354 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlay'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT overlay(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:08.430173 [ 5978 ] {efc9187e-948a-430c-a545-cffc4673d708} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlayUTF8'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT overlayUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 980, line 981) (in query: SELECT overlayUTF8(-1);) 2025.06.13 15:45:08.443519 [ 8431 ] {6742738d-91b4-4f4c-be58-a12d62edf7f3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1231, line 1235) (in query: SELECT snowflakeToDateTime();) 2025.06.13 15:45:08.458036 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'overlayUTF8'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT overlayUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:08.464435 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:08.554379 [ 8431 ] {b34efec4-72d9-4ea2-80a9-69d7f9c7e314} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime64'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1232, line 1236) (in query: SELECT snowflakeToDateTime64();) 2025.06.13 15:45:08.586150 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime64'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:08.602111 [ 5978 ] {dccf18de-2e2c-42c3-946e-b7e13e4d0acc} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Int8: In scope SELECT parseDateTime(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 981, line 982) (in query: SELECT parseDateTime(-1);) 2025.06.13 15:45:08.612925 [ 5163 ] {d53d0a33-6546-4601-843a-442641d4bf95} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41990) (comment: 00900_orc_arrow_parquet_maps.sh) (query 1, line 1) (in query: CREATE TABLE maps (m1 Map(UInt32, UInt32), m2 Map(String, String), m3 Map(UInt32, Tuple(UInt32, UInt32)), m4 Map(UInt32, Array(UInt32)), m5 Array(Map(UInt32, UInt32)), m6 Tuple(Map(UInt32, UInt32), Map(String, String)), m7 Array(Map(UInt32, Array(Tuple(Map(UInt32, UInt32), Tuple(UInt32)))))) ENGINE=Memory();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:45:08.618438 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Int8: In scope SELECT parseDateTime(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:08.645765 [ 5163 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:45:08.665854 [ 8431 ] {54eadfa1-de63-4f40-8350-485a690be8c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 0, should be 1: In scope SELECT soundex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1233, line 1237) (in query: SELECT soundex();) 2025.06.13 15:45:08.674655 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 0, should be 1: In scope SELECT soundex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:08.799295 [ 5978 ] {56327e49-cae5-4690-ba19-97e11b2507fe} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTime32BestEffort: In scope SELECT parseDateTime32BestEffort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 982, line 983) (in query: SELECT parseDateTime32BestEffort(-1);) 2025.06.13 15:45:08.799243 [ 8431 ] {457b8c3a-ae1a-4722-9fea-c7ba82f9f131} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 0, should be 1: In scope SELECT space(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1234, line 1238) (in query: SELECT space();) 2025.06.13 15:45:08.820286 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTime32BestEffort: In scope SELECT parseDateTime32BestEffort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:08.832131 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 0, should be 1: In scope SELECT space(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:08.926011 [ 5978 ] {5e434d22-c2b6-4de8-9db5-091f6ec33366} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTime32BestEffortOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTime32BestEffortOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 983, line 984) (in query: SELECT parseDateTime32BestEffortOrNull(-1);) 2025.06.13 15:45:08.926040 [ 8431 ] {eae4e79b-61e3-46e2-bc70-8c8e116d7b50} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1235, line 1239) (in query: SELECT sparkBar();) 2025.06.13 15:45:08.948951 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTime32BestEffortOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTime32BestEffortOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:08.949459 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:09.073099 [ 8431 ] {4f8bdb59-3333-4c43-9ed3-564d39117e35} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1236, line 1240) (in query: SELECT sparkbar();) 2025.06.13 15:45:09.073155 [ 5978 ] {8d5f0e0c-e025-4617-bbae-70f5aa9002a8} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTime32BestEffortOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTime32BestEffortOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 984, line 985) (in query: SELECT parseDateTime32BestEffortOrZero(-1);) 2025.06.13 15:45:09.080253 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTime32BestEffortOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTime32BestEffortOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:09.092925 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:09.148592 [ 5163 ] {4f285692-2262-45dc-839e-9eaf2f8ce355} executeQuery: Code: 60. DB::Exception: Table test_7.maps does not exist. Maybe you meant test_8jxj4fuj.days?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42006) (comment: 00900_orc_arrow_parquet_maps.sh) (query 1, line 1) (in query: INSERT INTO maps VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:09.182457 [ 5163 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.maps does not exist. Maybe you meant test_8jxj4fuj.days?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:09.185071 [ 5978 ] {92f79beb-a753-4421-b7b6-81f49cd3406c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64'. Expected: String, got: Int8: In scope SELECT parseDateTime64(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 985, line 986) (in query: SELECT parseDateTime64(-1);) 2025.06.13 15:45:09.207758 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64'. Expected: String, got: Int8: In scope SELECT parseDateTime64(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:09.230181 [ 8431 ] {7db88266-52f5-4227-8e9f-5443d01e81fb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByAlpha(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1237, line 1241) (in query: SELECT splitByAlpha();) 2025.06.13 15:45:09.259620 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByAlpha(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:09.265096 [ 5978 ] {f648272d-1ea4-40f1-84e8-df654a38ba57} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffort'. Expected: String or FixedString, got: Int8: In scope SELECT parseDateTime64BestEffort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 986, line 987) (in query: SELECT parseDateTime64BestEffort(-1);) 2025.06.13 15:45:09.276478 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffort'. Expected: String or FixedString, got: Int8: In scope SELECT parseDateTime64BestEffort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:09.493804 [ 5978 ] {29bb2bd8-54ba-4279-b907-4bae4eca6aec} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrNull'. Expected: String or FixedString, got: Int8: In scope SELECT parseDateTime64BestEffortOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 987, line 988) (in query: SELECT parseDateTime64BestEffortOrNull(-1);) 2025.06.13 15:45:09.500971 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrNull'. Expected: String or FixedString, got: Int8: In scope SELECT parseDateTime64BestEffortOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:09.575652 [ 8431 ] {47b41997-e26a-450f-9d53-12af44394567} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByChar'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByChar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1238, line 1242) (in query: SELECT splitByChar();) 2025.06.13 15:45:09.582197 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByChar'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByChar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:09.612559 [ 5978 ] {7d9571eb-c286-4bf3-8916-feebd627fce5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrZero'. Expected: String or FixedString, got: Int8: In scope SELECT parseDateTime64BestEffortOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 988, line 989) (in query: SELECT parseDateTime64BestEffortOrZero(-1);) 2025.06.13 15:45:09.624960 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrZero'. Expected: String or FixedString, got: Int8: In scope SELECT parseDateTime64BestEffortOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:09.635952 [ 8101 ] {41783814-d1b4-4300-beb4-d543f46692f1} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42034) (comment: 02902_select_subcolumns_from_engine_null.sql) (query 1, line 1) (in query: CREATE TABLE null_02902 (t Tuple(num Int64, str String)) ENGINE = Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:09.648484 [ 8431 ] {5154f0eb-1216-4e4e-8956-f4a3763a49a1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByNonAlpha'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByNonAlpha(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1239, line 1243) (in query: SELECT splitByNonAlpha();) 2025.06.13 15:45:09.652338 [ 8101 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:09.657013 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByNonAlpha'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByNonAlpha(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:09.698722 [ 5978 ] {0dfa2f3d-6939-4969-b5ea-dfa15f7519c6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUS'. Expected: String or FixedString, got: Int8: In scope SELECT parseDateTime64BestEffortUS(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 989, line 990) (in query: SELECT parseDateTime64BestEffortUS(-1);) 2025.06.13 15:45:09.710588 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUS'. Expected: String or FixedString, got: Int8: In scope SELECT parseDateTime64BestEffortUS(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:09.735550 [ 5005 ] {330526d3-ddf9-4b4f-820b-df20977a6f67} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'maps' in scope SELECT * FROM maps. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42066) (comment: 00900_orc_arrow_parquet_maps.sh) (query 1, line 1) (in query: SELECT * FROM maps FORMAT Arrow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:45:09.743160 [ 8431 ] {969cc2e0-9306-4868-bf34-22368abffdeb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByRegexp'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByRegexp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1240, line 1244) (in query: SELECT splitByRegexp();) 2025.06.13 15:45:09.768283 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByRegexp'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByRegexp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:09.850011 [ 5005 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'maps' in scope SELECT * FROM maps. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:45:09.899551 [ 5978 ] {fa054666-ecdc-4518-a849-56f30663c313} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrNull'. Expected: String or FixedString, got: Int8: In scope SELECT parseDateTime64BestEffortUSOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 990, line 991) (in query: SELECT parseDateTime64BestEffortUSOrNull(-1);) 2025.06.13 15:45:09.906487 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrNull'. Expected: String or FixedString, got: Int8: In scope SELECT parseDateTime64BestEffortUSOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:09.938434 [ 8431 ] {793cb761-4b98-4257-9506-9fc87f3892f7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByString'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1241, line 1245) (in query: SELECT splitByString();) 2025.06.13 15:45:09.945395 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByString'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:09.977168 [ 5978 ] {994b0175-0336-4fed-b271-8401c2227886} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrZero'. Expected: String or FixedString, got: Int8: In scope SELECT parseDateTime64BestEffortUSOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 991, line 992) (in query: SELECT parseDateTime64BestEffortUSOrZero(-1);) 2025.06.13 15:45:09.988585 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrZero'. Expected: String or FixedString, got: Int8: In scope SELECT parseDateTime64BestEffortUSOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:10.030687 [ 8431 ] {e0160773-02fd-4215-8cc6-ac8538a7ba5c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByWhitespace'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByWhitespace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1242, line 1246) (in query: SELECT splitByWhitespace();) 2025.06.13 15:45:10.060784 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByWhitespace'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByWhitespace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:10.063878 [ 5978 ] {4b0ff1b6-2595-425d-905d-ed2cf7a4c656} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntax'. Expected: String, got: Int8: In scope SELECT parseDateTime64InJodaSyntax(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 992, line 993) (in query: SELECT parseDateTime64InJodaSyntax(-1);) 2025.06.13 15:45:10.069075 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntax'. Expected: String, got: Int8: In scope SELECT parseDateTime64InJodaSyntax(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:10.142209 [ 8431 ] {a2231e5a-44e8-40f5-bb65-09a714e8d836} executeQuery: Code: 42. DB::Exception: Function sqidEncode requires at least one argument.: In scope SELECT sqid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1243, line 1247) (in query: SELECT sqid();) 2025.06.13 15:45:10.163471 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function sqidEncode requires at least one argument.: In scope SELECT sqid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:10.167729 [ 5978 ] {db7ae84b-a2d6-4f07-9949-cdcb1b6ac685} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrNull'. Expected: String, got: Int8: In scope SELECT parseDateTime64InJodaSyntaxOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 993, line 994) (in query: SELECT parseDateTime64InJodaSyntaxOrNull(-1);) 2025.06.13 15:45:10.185100 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrNull'. Expected: String, got: Int8: In scope SELECT parseDateTime64InJodaSyntaxOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:10.261792 [ 8431 ] {66eebf60-d4c2-4db6-a3ae-76ba1875275f} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1244, line 1248) (in query: SELECT sqidDecode();) 2025.06.13 15:45:10.271319 [ 8431 ] {} 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) 2025.06.13 15:45:10.314302 [ 5978 ] {1f22fd37-db2f-40a7-af72-d8a2942ea5c0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrZero'. Expected: String, got: Int8: In scope SELECT parseDateTime64InJodaSyntaxOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 994, line 995) (in query: SELECT parseDateTime64InJodaSyntaxOrZero(-1);) 2025.06.13 15:45:10.322186 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrZero'. Expected: String, got: Int8: In scope SELECT parseDateTime64InJodaSyntaxOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:10.343400 [ 8101 ] {13e5c47e-e419-45d1-9438-7df16225de99} executeQuery: Code: 60. DB::Exception: Table test_7.maps does not exist. Maybe you meant test_8jxj4fuj.days?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42104) (comment: 00900_orc_arrow_parquet_maps.sh) (query 1, line 1) (in query: TRUNCATE TABLE maps), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:45:10.374114 [ 8431 ] {f003d7ad-3727-40dd-ad23-4d489fd8e4b6} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1245, line 1249) (in query: SELECT sqidEncode();) 2025.06.13 15:45:10.374453 [ 8101 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.maps does not exist. Maybe you meant test_8jxj4fuj.days?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:45:10.397699 [ 5978 ] {483e5909-c318-43ba-b12e-343a64ae4f05} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrNull'. Expected: String, got: Int8: In scope SELECT parseDateTime64OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 995, line 996) (in query: SELECT parseDateTime64OrNull(-1);) 2025.06.13 15:45:10.414275 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function sqidEncode requires at least one argument.: In scope SELECT sqidEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:10.416173 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrNull'. Expected: String, got: Int8: In scope SELECT parseDateTime64OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:10.510356 [ 5978 ] {d14866f7-eb8d-4c3c-85fb-d5a1e9b00cd5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrZero'. Expected: String, got: Int8: In scope SELECT parseDateTime64OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 996, line 997) (in query: SELECT parseDateTime64OrZero(-1);) 2025.06.13 15:45:10.525896 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrZero'. Expected: String, got: Int8: In scope SELECT parseDateTime64OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:10.638311 [ 5978 ] {5c7efb15-c1ea-4d15-9e6f-abf6bb69b561} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTimeBestEffort: In scope SELECT parseDateTimeBestEffort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 997, line 998) (in query: SELECT parseDateTimeBestEffort(-1);) 2025.06.13 15:45:10.667993 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTimeBestEffort: In scope SELECT parseDateTimeBestEffort(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:10.669761 [ 8431 ] {39f2262f-1347-4c7c-a2bb-d0f216b645c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 0, should be 1: In scope SELECT sqrt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1246, line 1250) (in query: SELECT sqrt();) 2025.06.13 15:45:10.731480 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 0, should be 1: In scope SELECT sqrt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:10.740424 [ 5978 ] {774d1350-559b-4b84-ad8d-300b84e9de3e} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTimeBestEffortOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 998, line 999) (in query: SELECT parseDateTimeBestEffortOrNull(-1);) 2025.06.13 15:45:10.754842 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTimeBestEffortOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:10.887483 [ 8431 ] {35361000-0caa-4374-afcb-1e8bd71a29aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 0, should be 2: In scope SELECT startsWith(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1247, line 1251) (in query: SELECT startsWith();) 2025.06.13 15:45:10.897441 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 0, should be 2: In scope SELECT startsWith(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:10.936885 [ 5978 ] {1bf3f5e2-df97-4c07-9b52-ad24c5bac6eb} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTimeBestEffortOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 999, line 1000) (in query: SELECT parseDateTimeBestEffortOrZero(-1);) 2025.06.13 15:45:10.975846 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTimeBestEffortOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:11.072343 [ 8431 ] {352eb1cf-6746-4398-bc6c-6de5ab3b8f7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 0, should be 2: In scope SELECT startsWithUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1248, line 1252) (in query: SELECT startsWithUTF8();) 2025.06.13 15:45:11.094798 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 0, should be 2: In scope SELECT startsWithUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:11.155974 [ 8101 ] {75ddd829-ba81-4f9d-a00a-56ca64db2e0f} executeQuery: Code: 43. DB::Exception: Illegal type Date of argument of function toTimezone. Should be DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTimeZone(N, 'UTC') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 2, line 2) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toTimeZone(N, 'UTC') as r FORMAT CSV;) 2025.06.13 15:45:11.194719 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of argument of function toTimezone. Should be DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTimeZone(N, 'UTC') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:11.236226 [ 5978 ] {7321ba8a-fd25-4f2f-8ca4-112c15ff3c68} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTimeBestEffortUS: In scope SELECT parseDateTimeBestEffortUS(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1000, line 1001) (in query: SELECT parseDateTimeBestEffortUS(-1);) 2025.06.13 15:45:11.243526 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTimeBestEffortUS: In scope SELECT parseDateTimeBestEffortUS(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:11.263499 [ 8431 ] {239820de-a938-44ae-a726-622e20c91550} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1249, line 1253) (in query: SELECT stddevPop();) 2025.06.13 15:45:11.269349 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:11.359991 [ 8431 ] {49944361-5bb5-44bb-9b79-472099041a01} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1250, line 1254) (in query: SELECT stddevPopStable();) 2025.06.13 15:45:11.382337 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:11.387118 [ 5978 ] {3950587b-04fe-4cdb-b069-7aff3b3980c1} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTimeBestEffortUSOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortUSOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1001, line 1002) (in query: SELECT parseDateTimeBestEffortUSOrNull(-1);) 2025.06.13 15:45:11.404048 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTimeBestEffortUSOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortUSOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:11.433797 [ 5110 ] {dffdca7e-59ad-4dbf-aede-01528d71a2a6} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'maps' in scope SELECT * FROM maps. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42166) (comment: 00900_orc_arrow_parquet_maps.sh) (query 1, line 1) (in query: SELECT * FROM maps), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:45:11.481456 [ 8431 ] {62783258-295e-4ffa-846c-07d3986ba67c} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1251, line 1255) (in query: SELECT stddevSamp();) 2025.06.13 15:45:11.530136 [ 5110 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'maps' in scope SELECT * FROM maps. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:45:11.532532 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:11.541710 [ 5978 ] {028ab013-50ee-4e26-91c2-71d89d1bac47} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTimeBestEffortUSOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortUSOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1002, line 1003) (in query: SELECT parseDateTimeBestEffortUSOrZero(-1);) 2025.06.13 15:45:11.583280 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function parseDateTimeBestEffortUSOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortUSOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:11.683494 [ 8431 ] {376e9d86-9786-496b-be7e-a0b1055171fb} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1252, line 1256) (in query: SELECT stddevSampStable();) 2025.06.13 15:45:11.722096 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:11.768048 [ 5978 ] {5d6e2894-c97e-4924-9b49-ab30549057c8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntax'. Expected: String, got: Int8: In scope SELECT parseDateTimeInJodaSyntax(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1003, line 1004) (in query: SELECT parseDateTimeInJodaSyntax(-1);) 2025.06.13 15:45:11.828298 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntax'. Expected: String, got: Int8: In scope SELECT parseDateTimeInJodaSyntax(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:11.842519 [ 8431 ] {d9e51c9d-2da1-4d20-bcb1-b6fdd02c7a32} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1253, line 1257) (in query: SELECT stem();) 2025.06.13 15:45:11.851595 [ 8431 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:45:11.947482 [ 5978 ] {fd439cff-0475-4ec9-bb91-0eb7a4c5e816} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrNull'. Expected: String, got: Int8: In scope SELECT parseDateTimeInJodaSyntaxOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1004, line 1005) (in query: SELECT parseDateTimeInJodaSyntaxOrNull(-1);) 2025.06.13 15:45:11.984063 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrNull'. Expected: String, got: Int8: In scope SELECT parseDateTimeInJodaSyntaxOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:12.074677 [ 8431 ] {f3628346-b858-4956-af2f-4e441e0b6dd7} executeQuery: Code: 35. DB::Exception: Aggregate function stochasticLinearRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1254, line 1258) (in query: SELECT stochasticLinearRegression();) 2025.06.13 15:45:12.080135 [ 5110 ] {d7fcbdc8-283d-4608-ab19-a9b8cd350d9d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'maps' in scope SELECT * FROM maps. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42202) (comment: 00900_orc_arrow_parquet_maps.sh) (query 1, line 1) (in query: SELECT * FROM maps FORMAT Parquet), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:45:12.082203 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function stochasticLinearRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:45:12.095228 [ 5110 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'maps' in scope SELECT * FROM maps. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:45:12.098631 [ 5978 ] {9fd83062-760b-4f3d-ac6e-2b606caeed1b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrZero'. Expected: String, got: Int8: In scope SELECT parseDateTimeInJodaSyntaxOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1005, line 1006) (in query: SELECT parseDateTimeInJodaSyntaxOrZero(-1);) 2025.06.13 15:45:12.131473 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrZero'. Expected: String, got: Int8: In scope SELECT parseDateTimeInJodaSyntaxOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:12.231205 [ 8431 ] {25a9fb47-b9f4-4b56-b1b7-3fae33f862ff} executeQuery: Code: 35. DB::Exception: Aggregate function stochasticLogisticRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1255, line 1259) (in query: SELECT stochasticLogisticRegression();) 2025.06.13 15:45:12.243955 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function stochasticLogisticRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:45:12.265337 [ 5978 ] {1a56b445-930a-416c-915c-9d5b9fe435d7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Int8: In scope SELECT parseDateTimeOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1006, line 1007) (in query: SELECT parseDateTimeOrNull(-1);) 2025.06.13 15:45:12.290508 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Int8: In scope SELECT parseDateTimeOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:12.351984 [ 8431 ] {45a5cdea-0f23-420d-bf4c-005a8e68af06} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT str_to_date(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1256, line 1260) (in query: SELECT str_to_date();) 2025.06.13 15:45:12.377390 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT str_to_date(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:12.390710 [ 5978 ] {21c15326-e33d-4fcd-bc37-b0722595f8e8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrZero'. Expected: String, got: Int8: In scope SELECT parseDateTimeOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1007, line 1008) (in query: SELECT parseDateTimeOrZero(-1);) 2025.06.13 15:45:12.412842 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrZero'. Expected: String, got: Int8: In scope SELECT parseDateTimeOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:12.500916 [ 8431 ] {3062af16-934d-425a-bc6e-2acf74989312} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT str_to_map(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1257, line 1261) (in query: SELECT str_to_map();) 2025.06.13 15:45:12.511329 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT str_to_map(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:12.610518 [ 5978 ] {a5de2953-fcd7-449f-bb80-4e1d80344f31} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSize'. Expected: String, got: Int8: In scope SELECT parseReadableSize(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1008, line 1009) (in query: SELECT parseReadableSize(-1);) 2025.06.13 15:45:12.620962 [ 8432 ] {991d9f3e-eb2b-4584-9158-9b412377f59a} executeQuery: Code: 60. DB::Exception: Table test_7.maps does not exist. Maybe you meant test_8jxj4fuj.days?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42252) (comment: 00900_orc_arrow_parquet_maps.sh) (query 1, line 1) (in query: TRUNCATE TABLE maps), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:45:12.623399 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSize'. Expected: String, got: Int8: In scope SELECT parseReadableSize(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:12.653457 [ 8432 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.maps does not exist. Maybe you meant test_8jxj4fuj.days?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:45:12.654271 [ 8431 ] {e314a5f7-8888-4e95-9b1c-c07584c60337} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 0, should be 2: In scope SELECT stringJaccardIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1258, line 1262) (in query: SELECT stringJaccardIndex();) 2025.06.13 15:45:12.661070 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 0, should be 2: In scope SELECT stringJaccardIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:12.738327 [ 5978 ] {29f2d4f7-b615-4d33-928e-26afbf659003} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSizeOrNull'. Expected: String, got: Int8: In scope SELECT parseReadableSizeOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1009, line 1010) (in query: SELECT parseReadableSizeOrNull(-1);) 2025.06.13 15:45:12.749003 [ 8431 ] {43e8547e-a903-4df3-85be-51a6e72be23a} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 0, should be 2: In scope SELECT stringJaccardIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1259, line 1263) (in query: SELECT stringJaccardIndexUTF8();) 2025.06.13 15:45:12.750292 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSizeOrNull'. Expected: String, got: Int8: In scope SELECT parseReadableSizeOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:12.753957 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 0, should be 2: In scope SELECT stringJaccardIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:12.835305 [ 5978 ] {03765ba7-6100-47a4-8d72-ecb48777b115} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSizeOrZero'. Expected: String, got: Int8: In scope SELECT parseReadableSizeOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1010, line 1011) (in query: SELECT parseReadableSizeOrZero(-1);) 2025.06.13 15:45:12.866727 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'readable_size' to function 'parseReadableSizeOrZero'. Expected: String, got: Int8: In scope SELECT parseReadableSizeOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:12.905751 [ 8431 ] {13f20043-7e97-4e73-bee6-a1019debaad9} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 0, should be 1: In scope SELECT stringToH3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1260, line 1264) (in query: SELECT stringToH3();) 2025.06.13 15:45:12.910116 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 0, should be 1: In scope SELECT stringToH3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:12.973110 [ 5978 ] {90fa80f5-5ce9-4d0d-87a3-e22c9179646b} executeQuery: Code: 43. DB::Exception: Cannot format Int8 as time string.: In scope SELECT parseTimeDelta(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1011, line 1012) (in query: SELECT parseTimeDelta(-1);) 2025.06.13 15:45:12.977622 [ 8431 ] {13914ffc-1569-4a4e-8060-6f3d01f26635} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 0, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1261, line 1265) (in query: SELECT structureToCapnProtoSchema();) 2025.06.13 15:45:12.994900 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Cannot format Int8 as time string.: In scope SELECT parseTimeDelta(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:13.014313 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 0, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:13.172119 [ 8431 ] {1b3c2e00-40dd-4405-9d50-a249f39e9d9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 0, expected 1 or 2: In scope SELECT structureToProtobufSchema(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1262, line 1266) (in query: SELECT structureToProtobufSchema();) 2025.06.13 15:45:13.236531 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 0, expected 1 or 2: In scope SELECT structureToProtobufSchema(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:13.417878 [ 8431 ] {6732c921-20d2-4cb6-a4b1-ecde58133ab2} executeQuery: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1263, line 1267) (in query: SELECT studentTTest();) 2025.06.13 15:45:13.423750 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:13.504098 [ 8431 ] {3686b625-4761-44e1-ad42-260803335eb2} executeQuery: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 0, should be 3: In scope SELECT subBitmap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1264, line 1268) (in query: SELECT subBitmap();) 2025.06.13 15:45:13.526117 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 0, should be 3: In scope SELECT subBitmap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:13.613697 [ 5110 ] {0e827889-44d1-4948-8356-e06e14f1af3e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'maps' in scope SELECT * FROM maps. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46704) (comment: 00900_orc_arrow_parquet_maps.sh) (query 1, line 1) (in query: SELECT * FROM maps), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:45:13.636430 [ 5110 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'maps' in scope SELECT * FROM maps. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:45:13.645526 [ 5978 ] {1a1357f5-f3a3-4c3f-b142-d7e604ca5b93} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function path: In scope SELECT path(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1014, line 1015) (in query: SELECT path(-1);) 2025.06.13 15:45:13.646623 [ 8431 ] {cc3a8ef6-324f-43cf-b426-1a5d5c28dd7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 0, should be 2: In scope SELECT subDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1265, line 1269) (in query: SELECT subDate();) 2025.06.13 15:45:13.675490 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function path: In scope SELECT path(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:13.694510 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 0, should be 2: In scope SELECT subDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:13.808505 [ 5978 ] {e1121f23-a888-4c8e-b508-f7db67b0c168} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function pathFull: In scope SELECT pathFull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1015, line 1016) (in query: SELECT pathFull(-1);) 2025.06.13 15:45:13.809906 [ 8431 ] {bc42013f-a011-405a-92fa-8eecfe6a1497} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT substr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1266, line 1270) (in query: SELECT substr();) 2025.06.13 15:45:13.825757 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function pathFull: In scope SELECT pathFull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:13.843500 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT substr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:13.999841 [ 8431 ] {3c16b1df-4a53-4585-a621-35f443782887} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 0, should be 3: In scope SELECT substringIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1267, line 1272) (in query: SELECT substringIndex();) 2025.06.13 15:45:14.006217 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 0, should be 3: In scope SELECT substringIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:14.027032 [ 5978 ] {9616f5dc-7d2a-42b0-81e5-47a6514b8ccf} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1016, line 1017) (in query: SELECT percentRank(-1);) 2025.06.13 15:45:14.030557 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:45:14.072174 [ 8431 ] {505143c7-e717-4678-8f7d-7f52787019ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 0, should be 3: In scope SELECT substringIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1268, line 1273) (in query: SELECT substringIndexUTF8();) 2025.06.13 15:45:14.076313 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 0, should be 3: In scope SELECT substringIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:14.136516 [ 5978 ] {0c082c66-d993-4bf2-9070-ee7b4e766b11} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1017, line 1018) (in query: SELECT percent_rank(-1);) 2025.06.13 15:45:14.143966 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:45:14.188265 [ 8431 ] {fb93440b-a4b0-4745-8e3f-4c8cf8229623} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT substringUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1269, line 1274) (in query: SELECT substringUTF8();) 2025.06.13 15:45:14.197925 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT substringUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:14.279137 [ 5978 ] {efa3021b-03a8-4c34-8348-f115fa6e8b4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 1, should be 0: In scope SELECT pi(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1018, line 1019) (in query: SELECT pi(-1);) 2025.06.13 15:45:14.294878 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 1, should be 0: In scope SELECT pi(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:14.309291 [ 9636 ] {2871fdbf-dddf-45d7-b767-edb451e57bc0} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'maps' in scope SELECT * FROM maps. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46762) (comment: 00900_orc_arrow_parquet_maps.sh) (query 1, line 1) (in query: SELECT * FROM maps FORMAT ORC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:45:14.344219 [ 9636 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'maps' in scope SELECT * FROM maps. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:45:14.362087 [ 8431 ] {993a1b09-1a3b-4e8c-b879-0ae60cb5dd21} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractDays doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractDays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1270, line 1275) (in query: SELECT subtractDays();) 2025.06.13 15:45:14.392915 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractDays doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractDays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:14.486142 [ 5978 ] {ebb66f65-1665-49b0-b66a-c7d423f18040} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT plus(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1019, line 1020) (in query: SELECT plus(-1);) 2025.06.13 15:45:14.502067 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT plus(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:14.541537 [ 8431 ] {c807bc8d-ec55-4de4-8137-606a8abd300e} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractHours doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractHours(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1271, line 1276) (in query: SELECT subtractHours();) 2025.06.13 15:45:14.550145 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractHours doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractHours(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:14.675850 [ 5978 ] {c8c497a9-efbf-4484-86c8-1bc3a8651b53} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 1, should be 2: In scope SELECT pmod(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1020, line 1021) (in query: SELECT pmod(-1);) 2025.06.13 15:45:14.690874 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 1, should be 2: In scope SELECT pmod(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:14.708115 [ 8431 ] {295a3603-fa71-4682-8833-f41e3da1e5b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 0, should be 2: In scope SELECT subtractInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1272, line 1277) (in query: SELECT subtractInterval();) 2025.06.13 15:45:14.716545 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 0, should be 2: In scope SELECT subtractInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:14.867967 [ 5978 ] {6fc1dbda-94a0-4dec-bbff-2c4cdca7aeb5} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1021, line 1022) (in query: SELECT pointInEllipses(-1);) 2025.06.13 15:45:14.877038 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:14.881419 [ 8431 ] {f51ce713-bd6a-4ff5-bbbc-98effdf0d1ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMicroseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMicroseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1273, line 1278) (in query: SELECT subtractMicroseconds();) 2025.06.13 15:45:14.924205 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMicroseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMicroseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:15.051934 [ 8099 ] {ea6213e1-b3f7-4020-910e-7f103807f5f1} executeQuery: Code: 60. DB::Exception: Table test_7.maps does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46818) (comment: 00900_orc_arrow_parquet_maps.sh) (query 1, line 1) (in query: TRUNCATE TABLE maps), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:45:15.053871 [ 8431 ] {0b46b41c-307f-4305-96ad-d7d6a26b150b} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMilliseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMilliseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1274, line 1279) (in query: SELECT subtractMilliseconds();) 2025.06.13 15:45:15.054772 [ 5978 ] {5df7e1c0-f7b6-45b2-9b9a-ac6fa9cfcf80} executeQuery: Code: 35. DB::Exception: Function pointInPolygon requires at least 2 arguments: In scope SELECT pointInPolygon(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1022, line 1023) (in query: SELECT pointInPolygon(-1);) 2025.06.13 15:45:15.096991 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMilliseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMilliseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:15.098651 [ 8099 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.maps does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:45:15.099192 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: Function pointInPolygon requires at least 2 arguments: In scope SELECT pointInPolygon(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:45:15.271543 [ 5978 ] {65d0a182-69ad-4ab0-99fa-fd5640117f17} executeQuery: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT polygonAreaCartesian(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1023, line 1024) (in query: SELECT polygonAreaCartesian(-1);) 2025.06.13 15:45:15.296308 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT polygonAreaCartesian(-1). (BAD_ARGUMENTS) 2025.06.13 15:45:15.346281 [ 8431 ] {df327515-61aa-4beb-b9a2-73dcded1c2b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMinutes doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1275, line 1280) (in query: SELECT subtractMinutes();) 2025.06.13 15:45:15.350850 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMinutes doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:15.450032 [ 8431 ] {0a530304-2ab0-41b4-9f6d-caf0c0710383} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMonths doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMonths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1276, line 1281) (in query: SELECT subtractMonths();) 2025.06.13 15:45:15.460588 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMonths doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMonths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:15.548300 [ 8431 ] {6b413d8e-d1e1-4eec-ac9d-2f7f5f90dc8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractNanoseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractNanoseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1277, line 1282) (in query: SELECT subtractNanoseconds();) 2025.06.13 15:45:15.557987 [ 5978 ] {6ac5df8a-60da-418f-b9d9-9f7fcea551a0} executeQuery: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT polygonAreaSpherical(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1024, line 1025) (in query: SELECT polygonAreaSpherical(-1);) 2025.06.13 15:45:15.568779 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractNanoseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractNanoseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:15.570966 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT polygonAreaSpherical(-1). (BAD_ARGUMENTS) 2025.06.13 15:45:15.633471 [ 3498 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {322eb610-7231-45f1-872a-f605008de98e::202506_1_76_15}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab57af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab1fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003122f56b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d8e4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:45:15.701616 [ 5978 ] {62be0aa4-4030-4a9d-b6fb-d17773f3edf4} executeQuery: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT polygonConvexHullCartesian(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1025, line 1026) (in query: SELECT polygonConvexHullCartesian(-1);) 2025.06.13 15:45:15.717390 [ 8431 ] {03668f78-2f12-45b2-a4a8-30de87845446} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractQuarters doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractQuarters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1278, line 1283) (in query: SELECT subtractQuarters();) 2025.06.13 15:45:15.748112 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT polygonConvexHullCartesian(-1). (BAD_ARGUMENTS) 2025.06.13 15:45:15.754106 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractQuarters doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractQuarters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:15.766485 [ 8442 ] {7810dc7e-2a64-43de-8f5b-68b3d80c8f8d} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46884) (comment: 02423_ddl_for_opentelemetry.sh) (query 1, line 1) (in query: CREATE TABLE test_11.ddl_test_for_opentelemetry ON CLUSTER test_11 (`id` UInt64) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 16095, 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 = 175104615, compact_parts_max_bytes_to_buffer = 253899654, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 13909844, merge_max_block_size = 4819, old_parts_lifetime = 339., prefer_fetch_merged_part_size_threshold = 1924087614, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3744371766, index_granularity_bytes = 14743602, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 15, 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 = 58084, primary_key_compress_block_size = 61446, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:15.781397 [ 8442 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:15.852844 [ 8431 ] {a25c242a-2793-45a0-a445-2edf6d04755e} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractSeconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractSeconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1279, line 1284) (in query: SELECT subtractSeconds();) 2025.06.13 15:45:15.881896 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractSeconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractSeconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:15.952135 [ 5978 ] {c32c67c1-c5ad-4942-89d5-f714a5868211} executeQuery: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT polygonPerimeterCartesian(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1026, line 1027) (in query: SELECT polygonPerimeterCartesian(-1);) 2025.06.13 15:45:15.977082 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT polygonPerimeterCartesian(-1). (BAD_ARGUMENTS) 2025.06.13 15:45:16.010491 [ 8431 ] {4b7b635d-f619-46b0-8292-05189401d069} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 0, should be 2: In scope SELECT subtractTupleOfIntervals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1280, line 1285) (in query: SELECT subtractTupleOfIntervals();) 2025.06.13 15:45:16.033077 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 0, should be 2: In scope SELECT subtractTupleOfIntervals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:16.045515 [ 18602 ] {c54ed1c3-dd46-4250-aee5-c03a7a5f92ea} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'maps' in scope SELECT * FROM maps. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46898) (comment: 00900_orc_arrow_parquet_maps.sh) (query 1, line 1) (in query: SELECT * FROM maps), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:45:16.072740 [ 18602 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'maps' in scope SELECT * FROM maps. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:45:16.150681 [ 5978 ] {67916844-ffa1-487e-b6bd-f309ecbcf869} executeQuery: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT polygonPerimeterSpherical(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1027, line 1028) (in query: SELECT polygonPerimeterSpherical(-1);) 2025.06.13 15:45:16.156404 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT polygonPerimeterSpherical(-1). (BAD_ARGUMENTS) 2025.06.13 15:45:16.172779 [ 8431 ] {49f2bacd-7dac-42df-bb21-31a496505593} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractWeeks doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractWeeks(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1281, line 1286) (in query: SELECT subtractWeeks();) 2025.06.13 15:45:16.206611 [ 18510 ] {52221d74-decd-4e08-9429-7eea68d28079} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:46790). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46790) (comment: 01040_dictionary_invalidate_query_switchover_long.sh) (query 1, line 1) (in query: SELECT last_exception FROM system.dictionaries WHERE database = currentDatabase() AND name = 'invalidate'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b951d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:45:16.273313 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractWeeks doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractWeeks(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:16.286714 [ 18510 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:46790). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b951d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:45:16.302245 [ 5978 ] {2bdc7ebb-7c48-4007-9e0d-0a7f9c18ab9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsDistanceCartesian(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1028, line 1029) (in query: SELECT polygonsDistanceCartesian(-1);) 2025.06.13 15:45:16.310751 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsDistanceCartesian(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:16.400847 [ 8431 ] {b44ed751-b7db-497f-9ff4-2287332c6100} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractYears doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractYears(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1282, line 1287) (in query: SELECT subtractYears();) 2025.06.13 15:45:16.478535 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractYears doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractYears(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:16.509686 [ 5978 ] {05c2ed28-c3eb-4cfa-bd44-768a206299eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsDistanceSpherical(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1029, line 1030) (in query: SELECT polygonsDistanceSpherical(-1);) 2025.06.13 15:45:16.529385 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsDistanceSpherical(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:16.640526 [ 8431 ] {927fc316-ffe4-4e9d-9251-51b9f3069d87} executeQuery: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1283, line 1288) (in query: SELECT sum();) 2025.06.13 15:45:16.653714 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:16.718139 [ 5978 ] {4af4d504-111d-44e4-ae95-b54687e8ba76} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsEqualsCartesian(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1030, line 1031) (in query: SELECT polygonsEqualsCartesian(-1);) 2025.06.13 15:45:16.730742 [ 18602 ] {9c7d4f9b-cd2a-4a4d-8583-dcba1342c103} executeQuery: Code: 60. DB::Exception: Table test_7.maps does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46942) (comment: 00900_orc_arrow_parquet_maps.sh) (query 1, line 1) (in query: DROP TABLE maps), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:45:16.731733 [ 5110 ] {2831e22a-af5a-43cc-a26a-613894951f96} executeQuery: Code: 69. DB::Exception: Scale 36 is out of bounds (max scale: 18): In scope SELECT e + e, e - e, e * e, e / e, intDiv(e, e), intDivOrZero(e, e) FROM decimal WHERE e > 0. (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 9, line 29) (in query: SELECT e + e, e - e, e * e, e / e, intDiv(e, e), intDivOrZero(e, e) FROM decimal WHERE e > 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccaf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c4047f6 6. auto DB::impl_::decimalResultType, DB::Decimal, DB::DataTypeDecimal>(DB::DataTypeDecimal> const&, DB::Decimal> const&) @ 0x000000001f156d67 7. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001f380607 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f37e17f 9. auto bool DB::FunctionBinaryArithmetic::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000001f35ed12 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f35e75f 11. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001f35d744 12. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f062e31 13. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:45:16.736773 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsEqualsCartesian(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:16.840355 [ 8431 ] {809cb90a-6733-45c0-99aa-cfb6af2b6a23} executeQuery: Code: 42. DB::Exception: Aggregate function sumCount requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1284, line 1289) (in query: SELECT sumCount();) 2025.06.13 15:45:16.842324 [ 5110 ] {} TCPHandler: Code: 69. DB::Exception: Scale 36 is out of bounds (max scale: 18): In scope SELECT e + e, e - e, e * e, e / e, intDiv(e, e), intDivOrZero(e, e) FROM decimal WHERE e > 0. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccaf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c4047f6 6. auto DB::impl_::decimalResultType, DB::Decimal, DB::DataTypeDecimal>(DB::DataTypeDecimal> const&, DB::Decimal> const&) @ 0x000000001f156d67 7. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001f380607 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f37e17f 9. auto bool DB::FunctionBinaryArithmetic::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000001f35ed12 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f35e75f 11. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001f35d744 12. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f062e31 13. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:45:16.850571 [ 18602 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.maps does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:45:16.852366 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sumCount requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:16.935666 [ 5978 ] {f725c517-8fa3-4b57-89b4-602caf65e4ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsIntersectionCartesian(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1031, line 1032) (in query: SELECT polygonsIntersectionCartesian(-1);) 2025.06.13 15:45:16.952651 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsIntersectionCartesian(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:16.959499 [ 8431 ] {feca93d0-d813-45c6-af2c-6859a824bf56} executeQuery: Code: 42. DB::Exception: Aggregate function sumKahan requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1285, line 1290) (in query: SELECT sumKahan();) 2025.06.13 15:45:16.989772 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sumKahan requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:17.077300 [ 5110 ] {81fcc3db-d896-4766-b0be-9d377dc04a64} executeQuery: Code: 69. DB::Exception: Scale 76 is out of bounds (max scale: 38): In scope SELECT f + f, f - f, f * f, f / f, intDiv(f, f), intDivOrZero(f, f) FROM decimal WHERE f > 0. (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 10, line 30) (in query: SELECT f + f, f - f, f * f, f / f, intDiv(f, f), intDivOrZero(f, f) FROM decimal WHERE f > 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccaf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c404fb6 6. auto DB::impl_::decimalResultType>, DB::Decimal>, DB::DataTypeDecimal>(DB::DataTypeDecimal>> const&, DB::Decimal>>> const&) @ 0x000000001f17a647 7. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000001f383b07 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f3814bf 9. auto bool DB::FunctionBinaryArithmetic::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const @ 0x000000001f35ed72 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f35e79f 11. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001f35d744 12. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f062e31 13. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:45:17.094141 [ 5110 ] {} TCPHandler: Code: 69. DB::Exception: Scale 76 is out of bounds (max scale: 38): In scope SELECT f + f, f - f, f * f, f / f, intDiv(f, f), intDivOrZero(f, f) FROM decimal WHERE f > 0. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccaf6f 5. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x000000002c404fb6 6. auto DB::impl_::decimalResultType>, DB::Decimal>, DB::DataTypeDecimal>(DB::DataTypeDecimal>> const&, DB::Decimal>>> const&) @ 0x000000001f17a647 7. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000001f383b07 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f3814bf 9. auto bool DB::FunctionBinaryArithmetic::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const @ 0x000000001f35ed72 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f35e79f 11. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001f35d744 12. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001f062e31 13. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:45:17.117328 [ 8431 ] {b56d09ff-ae52-40f9-813b-34b20a979a19} executeQuery: Code: 42. DB::Exception: Aggregate function sumMapFiltered requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1286, line 1291) (in query: SELECT sumMapFiltered();) 2025.06.13 15:45:17.138623 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sumMapFiltered requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:17.148807 [ 5978 ] {bc958585-3b78-4810-85f5-75e229ebe8fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsIntersectionSpherical(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1032, line 1033) (in query: SELECT polygonsIntersectionSpherical(-1);) 2025.06.13 15:45:17.162553 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsIntersectionSpherical(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:17.338333 [ 8431 ] {f6f6935b-5bfe-4adf-8e40-440da599c102} executeQuery: Code: 42. DB::Exception: Aggregate function sumMapFilteredWithOverflow requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1287, line 1292) (in query: SELECT sumMapFilteredWithOverflow();) 2025.06.13 15:45:17.344576 [ 5978 ] {d957d475-8b1e-4627-86eb-18ef210429cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsSymDifferenceCartesian(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1033, line 1034) (in query: SELECT polygonsSymDifferenceCartesian(-1);) 2025.06.13 15:45:17.348607 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sumMapFilteredWithOverflow requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:17.371376 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsSymDifferenceCartesian(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:17.529688 [ 8431 ] {84a21938-8fbf-45a5-bbb6-f4f1e2e439bd} executeQuery: Code: 42. DB::Exception: Aggregate function sumMapWithOverflow requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1288, line 1293) (in query: SELECT sumMapWithOverflow();) 2025.06.13 15:45:17.541642 [ 5978 ] {86efc1d2-0fa4-40b7-96b3-1cff59bd833f} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsSymDifferenceSpherical(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1034, line 1035) (in query: SELECT polygonsSymDifferenceSpherical(-1);) 2025.06.13 15:45:17.550334 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sumMapWithOverflow requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:17.550939 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsSymDifferenceSpherical(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:17.620384 [ 8432 ] {6a097525-864b-4ad9-8925-81fe5366a40c} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46960) (comment: 01040_dictionary_invalidate_query_switchover_long.sh) (query 1, line 2) (in query: CREATE TABLE dict_invalidate ENGINE = Memory AS SELECT 133 as dummy, toDateTime('2019-10-29 18:51:35') AS last_time FROM system.one), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:17.642241 [ 8432 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:17.684554 [ 8431 ] {1568e604-0f39-42ca-bba0-6547e1b50752} executeQuery: Code: 42. DB::Exception: Aggregate function sumMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1289, line 1294) (in query: SELECT sumMappedArrays();) 2025.06.13 15:45:17.689845 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sumMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:17.708630 [ 5110 ] {8b8fec35-1cde-40b1-961a-e5678539ae21} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION multiply(__table1.h : 0, __table1.h : 0) -> multiply(__table1.h, __table1.h) Decimal(18, 18) : 3'. (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 12, line 32) (in query: SELECT h + h, h - h, h * h, h / h, intDiv(h, h), intDivOrZero(h, h) FROM decimal WHERE h > 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::impl_::DecimalBinaryOperation, true>::processWithRightNullmapImpl<(DB::impl_::OpCase)0, void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)0, true, true, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*)::'lambda'(auto const&, auto const&), DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long, DB::PODArray, 63ul, 64ul> const*, auto) @ 0x000000001f1578fb 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::ColumnDecimal>, DB::ColumnDecimal>>(DB::DataTypeDecimal> const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001f2e426f 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001f2e3e83 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001f2e3c2a 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f2d4b5f 10. auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000001f1d0632 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f1d007f 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001f1cafe3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f1c7b0b 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:45:17.713639 [ 5978 ] {83a82a54-22ba-4106-8166-de41aa8dce87} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsUnionCartesian(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1035, line 1036) (in query: SELECT polygonsUnionCartesian(-1);) 2025.06.13 15:45:17.729557 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsUnionCartesian(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:17.730846 [ 5110 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION multiply(__table1.h : 0, __table1.h : 0) -> multiply(__table1.h, __table1.h) Decimal(18, 18) : 3'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::impl_::DecimalBinaryOperation, true>::processWithRightNullmapImpl<(DB::impl_::OpCase)0, void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)0, true, true, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*)::'lambda'(auto const&, auto const&), DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long, DB::PODArray, 63ul, 64ul> const*, auto) @ 0x000000001f1578fb 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::ColumnDecimal>, DB::ColumnDecimal>>(DB::DataTypeDecimal> const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001f2e426f 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001f2e3e83 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001f2e3c2a 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f2d4b5f 10. auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000001f1d0632 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001f1d007f 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001f1cafe3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f1c7b0b 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:45:17.767244 [ 8431 ] {6ef6f38c-03f8-4318-a0df-c9c75a16ebb9} executeQuery: Code: 42. DB::Exception: Aggregate function sumWithOverflow requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1290, line 1295) (in query: SELECT sumWithOverflow();) 2025.06.13 15:45:17.784807 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sumWithOverflow requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:17.839940 [ 5978 ] {db9fd341-eb6b-409e-8d75-13288d988dc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsUnionSpherical(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1036, line 1037) (in query: SELECT polygonsUnionSpherical(-1);) 2025.06.13 15:45:17.846462 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsUnionSpherical(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:17.917567 [ 8431 ] {1c0f4fc9-47c5-4281-8c88-6dd05082dbbe} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT svg(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1291, line 1296) (in query: SELECT svg();) 2025.06.13 15:45:17.950295 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT svg(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:17.961285 [ 5978 ] {4958bec2-2632-4087-b990-78a589e8393e} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsWithinCartesian(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1037, line 1038) (in query: SELECT polygonsWithinCartesian(-1);) 2025.06.13 15:45:17.995296 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 1, should be 2: In scope SELECT polygonsWithinCartesian(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:18.045276 [ 8431 ] {aa56cd3b-7573-4ea9-a751-bd011b66594b} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1292, line 1297) (in query: SELECT synonyms();) 2025.06.13 15:45:18.053486 [ 8431 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:45:18.093849 [ 5978 ] {fd46c885-ca53-4e56-b142-9064621355da} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsWithinSpherical(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1038, line 1039) (in query: SELECT polygonsWithinSpherical(-1);) 2025.06.13 15:45:18.112545 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 1, should be 2: In scope SELECT polygonsWithinSpherical(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:18.167445 [ 8431 ] {325b6815-d488-42e2-8f91-9930f28d59de} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 0, should be 1: In scope SELECT tan(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1293, line 1298) (in query: SELECT tan();) 2025.06.13 15:45:18.204113 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 0, should be 1: In scope SELECT tan(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:18.308426 [ 5978 ] {44ba601f-b207-4e6e-8742-d9e00db7cfb8} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function port. Must be String.: In scope SELECT port(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1039, line 1040) (in query: SELECT port(-1);) 2025.06.13 15:45:18.342226 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function port. Must be String.: In scope SELECT port(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:18.421998 [ 8431 ] {49bf6402-fc84-4bff-8410-185de405114e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 0, should be 1: In scope SELECT tanh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1294, line 1299) (in query: SELECT tanh();) 2025.06.13 15:45:18.430193 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 0, should be 1: In scope SELECT tanh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:18.456759 [ 5978 ] {a8b633f9-81dd-4950-b296-0ce7ddaf9ebe} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function portRFC. Must be String.: In scope SELECT portRFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1040, line 1041) (in query: SELECT portRFC(-1);) 2025.06.13 15:45:18.477720 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function portRFC. Must be String.: In scope SELECT portRFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:18.610978 [ 5978 ] {2c26c201-5e18-427b-9a1c-191688800137} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 1, should be 2 or 3: In scope SELECT positionCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1041, line 1043) (in query: SELECT positionCaseInsensitive(-1);) 2025.06.13 15:45:18.648941 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 1, should be 2 or 3: In scope SELECT positionCaseInsensitive(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:18.729628 [ 8431 ] {7c08b9db-1c9a-4e76-8da4-5359782aeea6} executeQuery: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 0, should be 2: In scope SELECT test_function(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1296, line 1301) (in query: SELECT test_function();) 2025.06.13 15:45:18.757889 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 0, should be 2: In scope SELECT test_function(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:18.768842 [ 5978 ] {3bc59171-d037-4896-ac2b-9d9c6336a02d} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitiveUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT positionCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1042, line 1044) (in query: SELECT positionCaseInsensitiveUTF8(-1);) 2025.06.13 15:45:18.776093 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitiveUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT positionCaseInsensitiveUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:18.888556 [ 8431 ] {91b6bd1e-b479-4cb6-8379-25fcca128071} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 0, should be 1: In scope SELECT tgamma(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1297, line 1302) (in query: SELECT tgamma();) 2025.06.13 15:45:18.927485 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 0, should be 1: In scope SELECT tgamma(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:18.949750 [ 5978 ] {4a961176-aef5-44d4-b8fa-f8c60f9bc68a} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT positionUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1043, line 1045) (in query: SELECT positionUTF8(-1);) 2025.06.13 15:45:18.964797 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT positionUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:19.012643 [ 8431 ] {21c71268-6a18-4886-a651-a23399fafe66} executeQuery: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1298, line 1303) (in query: SELECT theilsU();) 2025.06.13 15:45:19.030543 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:19.076996 [ 5978 ] {f11019ea-b6ba-43f4-8949-ca38677ced8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 1, should be 2: In scope SELECT positiveModulo(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1044, line 1046) (in query: SELECT positiveModulo(-1);) 2025.06.13 15:45:19.084235 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 1, should be 2: In scope SELECT positiveModulo(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:19.147128 [ 8431 ] {4452dcf2-5a9c-4561-b0c5-9a3ba7f29772} executeQuery: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 0, should be 1 or 2: In scope SELECT throwIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1299, line 1304) (in query: SELECT throwIf();) 2025.06.13 15:45:19.172192 [ 8101 ] {28e45bf6-553a-4df3-8fa9-fa906327fe19} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 37, line 37) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toHour(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:19.192473 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:19.204396 [ 5978 ] {443f6dad-3735-4bb2-acde-233dbb0d3b99} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 1, should be 2: In scope SELECT positive_modulo(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1045, line 1047) (in query: SELECT positive_modulo(-1);) 2025.06.13 15:45:19.227022 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 1, should be 2: In scope SELECT positive_modulo(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:19.242125 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 0, should be 1 or 2: In scope SELECT throwIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:19.329389 [ 5978 ] {28a17905-a43b-4275-8210-e3adfeb1d017} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 1, should be 2: In scope SELECT pow(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1046, line 1048) (in query: SELECT pow(-1);) 2025.06.13 15:45:19.335704 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 1, should be 2: In scope SELECT pow(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:19.437123 [ 5978 ] {26f7e0bc-c703-4152-b5dd-f168f0ae00aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 1, should be 2: In scope SELECT power(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1047, line 1049) (in query: SELECT power(-1);) 2025.06.13 15:45:19.446913 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 1, should be 2: In scope SELECT power(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:19.465570 [ 8431 ] {f1a71446-2f75-4c1c-b635-19fdb9d77f22} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 0, should be 2: In scope SELECT timeDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1301, line 1306) (in query: SELECT timeDiff();) 2025.06.13 15:45:19.493107 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 0, should be 2: In scope SELECT timeDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:19.535032 [ 5978 ] {8a03c5bb-9464-488c-8849-4928cdb5b84d} executeQuery: Code: 43. DB::Exception: The first argument type of function printf is Int8, but String type is expected: In scope SELECT printf(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1048, line 1050) (in query: SELECT printf(-1);) 2025.06.13 15:45:19.542956 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The first argument type of function printf is Int8, but String type is expected: In scope SELECT printf(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:19.596418 [ 8431 ] {7bca619c-a09c-4958-a663-b665dc0b1488} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlot doesn't match: passed 0, should be 1 or 2: In scope SELECT timeSlot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1302, line 1307) (in query: SELECT timeSlot();) 2025.06.13 15:45:19.609387 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlot doesn't match: passed 0, should be 1 or 2: In scope SELECT timeSlot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:19.690360 [ 5978 ] {706d7ef3-602d-46f9-9e44-af795edb501e} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 1, should be 6: In scope SELECT proportionsZTest(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1049, line 1051) (in query: SELECT proportionsZTest(-1);) 2025.06.13 15:45:19.717461 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 1, should be 6: In scope SELECT proportionsZTest(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:19.779382 [ 8431 ] {603c3806-fa10-417f-92fd-17f16d8588aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 0, should be 2 or 3: In scope SELECT timeSlots(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1303, line 1308) (in query: SELECT timeSlots();) 2025.06.13 15:45:19.830959 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 0, should be 2 or 3: In scope SELECT timeSlots(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:19.896231 [ 5978 ] {f7dc3f4d-c49e-460f-bd17-e673c1978afd} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function protocol: In scope SELECT protocol(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1050, line 1052) (in query: SELECT protocol(-1);) 2025.06.13 15:45:19.896450 [ 5110 ] {b3d98c9c-e076-4137-9f40-8f233edebd47} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.e : 0, 21_UInt8 : 1) -> plus(__table1.e, 21_UInt8) Decimal(18, 18) : 4'. (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 20, line 41) (in query: SELECT e + 21, e - 21, e - 84, e * 21, e * -21, e / 21, e / 84 FROM decimal WHERE e > 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, long>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001fc79845 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::ColumnDecimal>, DB::ColumnVector>(DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fe2e092 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fe2d8c3 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001fe2d66a 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001fe2c3bc 10. auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000001fd13272 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001fd12cbf 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0dc23 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0a540 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd08448 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 22. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 23. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:45:19.918549 [ 5110 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.e : 0, 21_UInt8 : 1) -> plus(__table1.e, 21_UInt8) Decimal(18, 18) : 4'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, long>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001fc79845 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::ColumnDecimal>, DB::ColumnVector>(DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fe2e092 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fe2d8c3 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001fe2d66a 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001fe2c3bc 10. auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000001fd13272 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001fd12cbf 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0dc23 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0a540 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd08448 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 22. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 23. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 31. ? @ 0x00007f2f4224dac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:45:19.928947 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function protocol: In scope SELECT protocol(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:20.108235 [ 5978 ] {e44723e4-a9e3-4299-a3ae-2726a09eb879} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function punycodeDecode: In scope SELECT punycodeDecode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1051, line 1053) (in query: SELECT punycodeDecode(-1);) 2025.06.13 15:45:20.121155 [ 8431 ] {fc4ee95a-834e-446c-b76d-fa6094810f14} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 0, should be 1: In scope SELECT timeZoneOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1305, line 1310) (in query: SELECT timeZoneOf();) 2025.06.13 15:45:20.127345 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function punycodeDecode: In scope SELECT punycodeDecode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:20.148112 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 0, should be 1: In scope SELECT timeZoneOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:20.161288 [ 8101 ] {0444954e-faf7-4d7d-aa96-56fb3c5b2640} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 42, line 42) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toMinute(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:20.171141 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:20.209280 [ 8431 ] {f526dd35-fafc-4ea6-a782-69c8af09b0ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 0, should be 1 or 2: In scope SELECT timeZoneOffset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1306, line 1311) (in query: SELECT timeZoneOffset();) 2025.06.13 15:45:20.220547 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 0, should be 1 or 2: In scope SELECT timeZoneOffset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:20.245874 [ 5978 ] {b17ba33e-bb47-4fee-8593-f7c0ebbc1c78} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function punycodeEncode: In scope SELECT punycodeEncode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1052, line 1054) (in query: SELECT punycodeEncode(-1);) 2025.06.13 15:45:20.265835 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function punycodeEncode: In scope SELECT punycodeEncode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:20.534608 [ 8431 ] {71adf661-1b97-46e8-b3ca-5dcd2edce70c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 0, must be 2, 3 or 4: In scope SELECT time_bucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1307, line 1312) (in query: SELECT time_bucket();) 2025.06.13 15:45:20.540287 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 0, must be 2, 3 or 4: In scope SELECT time_bucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:20.599014 [ 8431 ] {91008153-95fc-4847-bb10-ada66422bd90} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1308, line 1313) (in query: SELECT timestamp();) 2025.06.13 15:45:20.631677 [ 8431 ] {} 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) 2025.06.13 15:45:20.746592 [ 8431 ] {16b9a59b-c3cd-4985-a625-891c78a22fb8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1309, line 1314) (in query: SELECT timestampDiff();) 2025.06.13 15:45:20.757397 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:20.849027 [ 5978 ] {ab26726b-ad4c-446d-879b-31cad949ff83} executeQuery: Code: 42. DB::Exception: Aggregate function quantileBFloat16Weighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1055, line 1057) (in query: SELECT quantileBFloat16Weighted(-1);) 2025.06.13 15:45:20.859358 [ 8431 ] {637a8abc-098f-4659-95fa-954439ae21bf} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1310, line 1315) (in query: SELECT timestamp_diff();) 2025.06.13 15:45:20.861722 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileBFloat16Weighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:20.874629 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:21.037424 [ 5978 ] {e6862396-31d8-4cf2-bf0f-ec24b3687259} executeQuery: Code: 42. DB::Exception: Aggregate function quantileDD requires at least one param. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1056, line 1058) (in query: SELECT quantileDD(-1);) 2025.06.13 15:45:21.048119 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileDD requires at least one param. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:21.061401 [ 8101 ] {1fa7b247-428a-42b2-a74e-9a7c066a57ad} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toSecond: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toSecond(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 47, line 47) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toSecond(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:21.080479 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toSecond: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toSecond(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:21.117881 [ 5978 ] {91a4acde-a466-4c77-8440-5963c5beea8d} executeQuery: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1057, line 1059) (in query: SELECT quantileDeterministic(-1);) 2025.06.13 15:45:21.127414 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:21.218818 [ 8431 ] {bdcdf52c-18e6-49d2-bc8b-01772a76bb6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 0, should be 1: In scope SELECT timezoneOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1312, line 1317) (in query: SELECT timezoneOf();) 2025.06.13 15:45:21.228101 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 0, should be 1: In scope SELECT timezoneOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:21.298929 [ 8431 ] {ab763ed3-1f93-4ef6-b397-e0d3681695d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 0, should be 1 or 2: In scope SELECT timezoneOffset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1313, line 1318) (in query: SELECT timezoneOffset();) 2025.06.13 15:45:21.348728 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 0, should be 1 or 2: In scope SELECT timezoneOffset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:21.427933 [ 8431 ] {8973fb50-6e4c-4b98-9fff-704f96753e6c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toBFloat16'. Expected 1 argument, got 0 arguments: In scope SELECT toBFloat16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1314, line 1319) (in query: SELECT toBFloat16();) 2025.06.13 15:45:21.437275 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toBFloat16'. Expected 1 argument, got 0 arguments: In scope SELECT toBFloat16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:21.532447 [ 8431 ] {7edd58af-17ed-499a-92da-4ad9f886271c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBFloat16OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toBFloat16OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1315, line 1320) (in query: SELECT toBFloat16OrNull();) 2025.06.13 15:45:21.562358 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBFloat16OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toBFloat16OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:21.685621 [ 8431 ] {a7df8737-6dc7-4d83-836f-7a752aec1948} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBFloat16OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toBFloat16OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1316, line 1321) (in query: SELECT toBFloat16OrZero();) 2025.06.13 15:45:21.702062 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBFloat16OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toBFloat16OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:21.814123 [ 8431 ] {7c9ed784-6eda-44b8-9812-20eac8e37f71} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 0, should be 1: In scope SELECT toBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1317, line 1322) (in query: SELECT toBool();) 2025.06.13 15:45:21.832906 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 0, should be 1: In scope SELECT toBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:21.930445 [ 8431 ] {0f7906f1-160c-4ade-9727-dfd3ab226ece} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 0, should be 1: In scope SELECT toColumnTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1318, line 1323) (in query: SELECT toColumnTypeName();) 2025.06.13 15:45:21.946618 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 0, should be 1: In scope SELECT toColumnTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:22.118225 [ 8431 ] {55355b3d-2de5-4b13-b923-baaaf1c671ab} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1319, line 1324) (in query: SELECT toDate();) 2025.06.13 15:45:22.123230 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:22.256632 [ 8431 ] {c980d076-25f5-4fc1-bb5d-234e84d5571a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1320, line 1325) (in query: SELECT toDate32();) 2025.06.13 15:45:22.278917 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:22.371061 [ 5978 ] {07de16d5-cee0-4119-b88b-50e5e48ce9f6} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1063, line 1065) (in query: SELECT quantileExactWeighted(-1);) 2025.06.13 15:45:22.371576 [ 8431 ] {7b52fb70-e661-414f-8cdc-bc84ad5f722a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1321, line 1326) (in query: SELECT toDate32OrDefault();) 2025.06.13 15:45:22.379708 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:22.388360 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:22.473180 [ 5110 ] {48f0f6c7-9b9d-48d7-8dd4-2d8735802e0f} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(21_UInt8 : 1, __table1.e : 0) -> plus(21_UInt8, __table1.e) Decimal(18, 18) : 4'. (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 29, line 51) (in query: SELECT 21 + e, 21 - e, 84 - e, 21 * e, -21 * e, 21 / e, 84 / e FROM decimal WHERE e > 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001fb9b138 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd21275 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd20c43 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001fd209ea 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001fd13c5f 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001fd127c1 11. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0dc23 12. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0a540 13. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd08448 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:45:22.483090 [ 5110 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(21_UInt8 : 1, __table1.e : 0) -> plus(21_UInt8, __table1.e) Decimal(18, 18) : 4'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001fb9b138 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd21275 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd20c43 8. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001fd209ea 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001fd13c5f 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001fd127c1 11. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0dc23 12. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0a540 13. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd08448 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 21. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:45:22.511558 [ 5978 ] {cfd2a47b-8288-45f1-aeb0-f8f96d1efc3d} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactWeightedInterpolated requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1064, line 1066) (in query: SELECT quantileExactWeightedInterpolated(-1);) 2025.06.13 15:45:22.512902 [ 8431 ] {ab63cbb1-d1d2-4215-961c-21e676afe9f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDate32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1322, line 1327) (in query: SELECT toDate32OrNull();) 2025.06.13 15:45:22.521103 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactWeightedInterpolated requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:22.531161 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDate32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:22.534735 [ 18380 ] {a4b6737c-3faa-47f1-be03-8d52e61e11b5} executeQuery: Code: 36. DB::Exception: Dictionary (`invalidate`) not found: In scope SELECT dictGetUInt8('invalidate', 'two', toUInt64(133)). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47120) (comment: 01040_dictionary_invalidate_query_switchover_long.sh) (query 1, line 1) (in query: SELECT dictGetUInt8('invalidate', 'two', toUInt64(133))), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x000000002dbe2855 6. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x000000002dbe314f 7. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x0000000017f4c186 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017f4576a 9. DB::FunctionDictGetImpl, DB::NameDictGetUInt8, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f616a7 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:45:22.576316 [ 18380 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`invalidate`) not found: In scope SELECT dictGetUInt8('invalidate', 'two', toUInt64(133)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x000000002dbe2855 6. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x000000002dbe314f 7. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x0000000017f4c186 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017f4576a 9. DB::FunctionDictGetImpl, DB::NameDictGetUInt8, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f616a7 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:45:22.682813 [ 5978 ] {17b7bc09-6c15-4833-93db-2f1c0a8e2ff0} executeQuery: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one param. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1065, line 1067) (in query: SELECT quantileGK(-1);) 2025.06.13 15:45:22.683256 [ 8431 ] {524f6514-f6f9-4697-91ea-b123b9ab664f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDate32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1323, line 1328) (in query: SELECT toDate32OrZero();) 2025.06.13 15:45:22.688169 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one param. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:22.694427 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDate32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:22.767349 [ 5978 ] {b990613d-a1ef-48c0-81c8-15016ab954f7} executeQuery: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1066, line 1068) (in query: SELECT quantileInterpolatedWeighted(-1);) 2025.06.13 15:45:22.777653 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:22.820414 [ 8431 ] {68bf0fad-3254-429c-83f1-d26db9688c9e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1324, line 1329) (in query: SELECT toDateOrDefault();) 2025.06.13 15:45:22.846133 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:22.902190 [ 8101 ] {5448a749-a537-4ca3-8445-c886a2665578} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 57, line 57) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfYear(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:22.912150 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:22.956029 [ 8431 ] {7e6c1e59-fa73-4f62-8e5c-bd4ed0f954ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1325, line 1330) (in query: SELECT toDateOrNull();) 2025.06.13 15:45:22.972758 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:23.126845 [ 5978 ] {10f54c87-8020-4933-943c-1327cea1152b} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1068, line 1070) (in query: SELECT quantileTDigestWeighted(-1);) 2025.06.13 15:45:23.134344 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:23.144830 [ 8431 ] {76eb8943-a951-4eb1-b2ee-2ddef47d8c75} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1326, line 1331) (in query: SELECT toDateOrZero();) 2025.06.13 15:45:23.165106 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:23.243145 [ 5110 ] {ae292bfe-41be-4aff-a994-f10646cae9a5} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION divide(21_UInt8 :: 1, __table1.h : 0) -> divide(21_UInt8, __table1.h) Decimal(18, 9) : 7'. (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 32, line 54) (in query: SELECT 21 + h, 21 - h, 84 - h, 21 * h, -21 * h, 21 / h, 84 / h FROM decimal WHERE h > 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. long DB::impl_::DecimalBinaryOperation, true>::applyScaledDiv(long, long, long) @ 0x000000001a08f50d 6. void DB::impl_::DecimalBinaryOperation, true>::processWithRightNullmapImpl<(DB::impl_::OpCase)1, void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*)::'lambda'(auto const&, auto const&), long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long, DB::PODArray, 63ul, 64ul> const*, auto) @ 0x000000001a090237 7. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001a08ff4b 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43f40a 9. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43ecc3 10. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43ea6a 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a4318ff 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a430461 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 2025.06.13 15:45:23.251920 [ 5110 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION divide(21_UInt8 :: 1, __table1.h : 0) -> divide(21_UInt8, __table1.h) Decimal(18, 9) : 7'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. long DB::impl_::DecimalBinaryOperation, true>::applyScaledDiv(long, long, long) @ 0x000000001a08f50d 6. void DB::impl_::DecimalBinaryOperation, true>::processWithRightNullmapImpl<(DB::impl_::OpCase)1, void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*)::'lambda'(auto const&, auto const&), long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long, DB::PODArray, 63ul, 64ul> const*, auto) @ 0x000000001a090237 7. void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000001a08ff4b 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43f40a 9. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43ecc3 10. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43ea6a 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a4318ff 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a430461 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:45:23.282620 [ 8431 ] {3c1d4f7d-6b6f-4e40-9277-50fb8033b127} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1327, line 1332) (in query: SELECT toDateTime();) 2025.06.13 15:45:23.294326 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:23.381550 [ 8431 ] {37977491-9c45-405f-97f5-6d81e3b99818} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime32'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateTime32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1328, line 1333) (in query: SELECT toDateTime32();) 2025.06.13 15:45:23.392082 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime32'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateTime32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:23.483266 [ 8431 ] {a8710f6d-2513-4b76-9097-29965c318f71} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1329, line 1334) (in query: SELECT toDateTime64();) 2025.06.13 15:45:23.485278 [ 18377 ] {d7aed14d-2bb7-4ae1-9066-5fdf7d8cba17} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37992) (comment: 02293_h3_distance.sql) (query 2, line 5) (in query: CREATE TABLE h3_indexes (id int, start String, end String) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:23.504547 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:23.505626 [ 18377 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:23.530200 [ 5978 ] {501fad19-9abf-4cdd-848a-430b072707df} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1070, line 1072) (in query: SELECT quantileTimingWeighted(-1);) 2025.06.13 15:45:23.542010 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:23.645130 [ 8431 ] {fafd4ae9-7e8c-4c22-b157-308009aec83c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrDefault'. Expected 2 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1330, line 1335) (in query: SELECT toDateTime64OrDefault();) 2025.06.13 15:45:23.663061 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrDefault'. Expected 2 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:23.736185 [ 5978 ] {b38825de-139c-48cb-bd70-4b7bb5609291} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1071, line 1073) (in query: SELECT quantiles(-1);) 2025.06.13 15:45:23.763866 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:23.825286 [ 8431 ] {ae2ac17f-ca0a-41e9-8ff6-36a7e22941dc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1331, line 1336) (in query: SELECT toDateTime64OrNull();) 2025.06.13 15:45:23.850008 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:23.876070 [ 5978 ] {715b997b-c791-4aa7-b62a-e4fd5cbf5ae5} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1072, line 1074) (in query: SELECT quantilesBFloat16(-1);) 2025.06.13 15:45:23.896172 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:23.902103 [ 8101 ] {b5cf0c11-c5c6-406e-bf6b-5a61d666c184} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfISOYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfISOYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 62, line 62) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfISOYear(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:23.916507 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfISOYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfISOYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:23.974226 [ 8431 ] {6a0ba311-b97d-4e77-b1fa-0f3cb09ce787} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1332, line 1337) (in query: SELECT toDateTime64OrZero();) 2025.06.13 15:45:23.980267 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:23.990864 [ 5978 ] {571d4391-364e-419f-a9f8-e284624480ad} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1073, line 1075) (in query: SELECT quantilesBFloat16Weighted(-1);) 2025.06.13 15:45:24.012250 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.055648 [ 8431 ] {4a5d1650-075f-4530-b7e1-0c4a2f5063e5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTimeOrDefault'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTimeOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1333, line 1338) (in query: SELECT toDateTimeOrDefault();) 2025.06.13 15:45:24.062454 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTimeOrDefault'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTimeOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.136491 [ 5978 ] {017eadbe-7742-4d9d-8caa-656799fc369a} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1074, line 1076) (in query: SELECT quantilesDD(-1);) 2025.06.13 15:45:24.180153 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.193543 [ 8431 ] {6f8d7bc0-ba47-4a07-91cc-a0d20e642646} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1334, line 1339) (in query: SELECT toDateTimeOrNull();) 2025.06.13 15:45:24.201446 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.256011 [ 5978 ] {a1537367-b721-441d-9f5c-0b345cd659f7} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1075, line 1077) (in query: SELECT quantilesDeterministic(-1);) 2025.06.13 15:45:24.270412 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.290178 [ 8431 ] {56997309-7f2c-4b44-8177-2a8b89fbc4e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1335, line 1340) (in query: SELECT toDateTimeOrZero();) 2025.06.13 15:45:24.301657 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.343869 [ 5978 ] {8525b3ad-241e-4d08-9c33-f9dcbfe6339d} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1076, line 1078) (in query: SELECT quantilesExact(-1);) 2025.06.13 15:45:24.385909 [ 8431 ] {a8cb2bfd-c773-4364-8c86-57fc3e0e6df3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toDayOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1336, line 1341) (in query: SELECT toDayOfMonth();) 2025.06.13 15:45:24.398996 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toDayOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.456392 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.535489 [ 8431 ] {50785409-be81-4a7c-a583-863a442fe5b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toDayOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1337, line 1342) (in query: SELECT toDayOfWeek();) 2025.06.13 15:45:24.540609 [ 5978 ] {6c879844-6c84-4e36-9760-f0077aaa5d03} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1077, line 1079) (in query: SELECT quantilesExactExclusive(-1);) 2025.06.13 15:45:24.542188 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toDayOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.547868 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.611387 [ 18377 ] {b652c2b6-3500-4d8d-aa8f-f5671dba3605} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38020) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 3, line 4) (in query: CREATE TABLE t1 (`key` String, `attr` String, `a` UInt64, `b` UInt64, `c` Nullable(UInt64)) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 709, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 535170660, compact_parts_max_bytes_to_buffer = 413929144, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 20547887, merge_max_block_size = 9548, old_parts_lifetime = 86., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 30591132, 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 = 97154, primary_key_compress_block_size = 8283, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:24.625017 [ 18377 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:24.654684 [ 5978 ] {538c1b72-a8d0-4a49-bda9-92b47f97da7a} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1078, line 1080) (in query: SELECT quantilesExactHigh(-1);) 2025.06.13 15:45:24.661613 [ 8101 ] {c35464e8-448a-4a1a-95e7-cf35dcb7e2d5} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfQuarter is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfQuarter(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 67, line 67) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfQuarter(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:24.668321 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.672119 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfQuarter is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfQuarter(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:24.703134 [ 8431 ] {fc0966d4-b54d-4541-b445-04d323aa3c3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toDayOfYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1338, line 1343) (in query: SELECT toDayOfYear();) 2025.06.13 15:45:24.712759 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toDayOfYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.770305 [ 5978 ] {4bb372a5-74f7-459a-ae44-3d0702fb9219} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1079, line 1081) (in query: SELECT quantilesExactInclusive(-1);) 2025.06.13 15:45:24.779578 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.867176 [ 8431 ] {16281c11-8df7-43c2-9144-9839fd6a6426} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT toDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1339, line 1344) (in query: SELECT toDaysSinceYearZero();) 2025.06.13 15:45:24.877643 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT toDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.912605 [ 5978 ] {ec65e1ac-dffc-426d-8466-101b5dde8e16} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1080, line 1082) (in query: SELECT quantilesExactLow(-1);) 2025.06.13 15:45:24.921908 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:24.975161 [ 8431 ] {3daf665a-ab08-44dd-9ced-57fd87643405} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1340, line 1345) (in query: SELECT toDecimal128();) 2025.06.13 15:45:24.984880 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:25.030163 [ 5978 ] {82424ce7-c84a-40bf-81a0-b82052129c48} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1081, line 1083) (in query: SELECT quantilesExactWeighted(-1);) 2025.06.13 15:45:25.059003 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:25.101591 [ 8431 ] {89d6b622-e360-460d-8932-e88da0203366} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1341, line 1346) (in query: SELECT toDecimal128OrDefault();) 2025.06.13 15:45:25.107471 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:25.155241 [ 5978 ] {6ddb01a3-289d-4894-b2ce-b592fbf0fcf2} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1082, line 1084) (in query: SELECT quantilesExactWeightedInterpolated(-1);) 2025.06.13 15:45:25.169272 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:25.263342 [ 8431 ] {3930ba5c-b575-4a65-a66a-07f49330a6a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1342, line 1347) (in query: SELECT toDecimal128OrNull();) 2025.06.13 15:45:25.271404 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:25.316319 [ 5978 ] {db87ec0b-fd01-4a58-88da-621ac8993bc1} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1083, line 1085) (in query: SELECT quantilesGK(-1);) 2025.06.13 15:45:25.335661 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:25.413283 [ 8431 ] {21dd95ff-6694-45b2-8817-448e848129b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1343, line 1348) (in query: SELECT toDecimal128OrZero();) 2025.06.13 15:45:25.421286 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:25.454225 [ 18380 ] {bbcf087e-480f-483a-b690-0c5e71f73cc9} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38122) (comment: 03322_initial_query_start_time_check.sql) (query 2, line 5) (in query: CREATE OR REPLACE VIEW tmp AS SELECT initialQueryStartTime() as it, now() AS t FROM system.one WHERE NOT ignore(sleep(0.1));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:25.493248 [ 18380 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:25.552691 [ 5978 ] {3e68b00b-0234-45ba-8a4b-fe6ea7faaa85} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1084, line 1086) (in query: SELECT quantilesInterpolatedWeighted(-1);) 2025.06.13 15:45:25.573982 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:25.651459 [ 8431 ] {fbc5d180-f149-4206-8b21-cf48de65599a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1344, line 1349) (in query: SELECT toDecimal256();) 2025.06.13 15:45:25.673672 [ 8600 ] {5f3d1ff0-6cb8-4f57-a400-5f2739b83da5} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_v1krk9sf.t_json_async_insert (data) FORMAT JSONAsObject' with query id 307bb2a6-cdb2-4da8-b92d-0679de5e3429. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) 2025.06.13 15:45:25.675041 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:25.680551 [ 5978 ] {21812061-e254-4f90-862d-192d461c9aee} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1085, line 1087) (in query: SELECT quantilesTDigest(-1);) 2025.06.13 15:45:25.694591 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:25.752679 [ 5112 ] {307bb2a6-cdb2-4da8-b92d-0679de5e3429} executeQuery: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38128) (comment: 02421_new_type_json_async_insert.sh) (query 1, line 1) (in query: INSERT INTO t_json_async_insert FORMAT JSONAsObject ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeObject(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x000000002c5b8378 6. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:393: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5b7dc5 7. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:52: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031a697b6 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 12. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x000000003183da52 13. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003183d525 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fe2df 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:45:25.807370 [ 5110 ] {dd49ee1e-fbea-4951-9706-c5289a60757e} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal32(0, 0). (ILLEGAL_DIVISION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 43, line 70) (in query: SELECT 1 / toDecimal32(0, 0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000001a08c356 6. DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, int, int, DB::Decimal, DB::Decimal>(int, int, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000001a43e95c 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43da5b 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43d7a3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43d54a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a4318bf 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a430461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:45:25.825525 [ 5110 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal32(0, 0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000001a08c356 6. DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, int, int, DB::Decimal, DB::Decimal>(int, int, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000001a43e95c 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43da5b 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43d7a3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43d54a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a4318bf 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a430461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:45:25.825999 [ 5112 ] {} TCPHandler: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeObject(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x000000002c5b8378 6. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:393: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5b7dc5 7. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:52: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031a697b6 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 12. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x000000003183da52 13. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003183d525 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fe2df 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:45:25.839548 [ 8431 ] {85605dae-38bf-4124-8b40-1ab1154de423} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1345, line 1350) (in query: SELECT toDecimal256OrDefault();) 2025.06.13 15:45:25.843332 [ 8101 ] {008a432b-85c2-45c0-80f8-bcd4978fa4a4} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfMonth is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMonth(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 72, line 72) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfMonth(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:25.852370 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfMonth is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMonth(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:25.854577 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:25.864733 [ 5978 ] {859f168e-4be6-453e-863f-db9f0948b5eb} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1086, line 1088) (in query: SELECT quantilesTDigestWeighted(-1);) 2025.06.13 15:45:25.883322 [ 5005 ] {89683831-48b0-45cf-9619-1bf7ebaf1ae5} executeQuery: Code: 582. DB::Exception: There is no projection pToDro in table. Maybe you meant: ['pToDrop']. (NO_SUCH_PROJECTION_IN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38174) (comment: 02250_hints_for_projections.sh) (query 1, line 1) (in query: ALTER TABLE t DROP PROJECTION pToDro), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Storages/ProjectionsDescription.cpp:424: DB::ProjectionsDescription::remove(String const&, bool) @ 0x000000003036387c 6. ./build_docker/./src/Storages/AlterCommands.cpp:860: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302baa62 7. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302c5739 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc6da9 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:45:25.898894 [ 5005 ] {} TCPHandler: Code: 582. DB::Exception: There is no projection pToDro in table. Maybe you meant: ['pToDrop']. (NO_SUCH_PROJECTION_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Storages/ProjectionsDescription.cpp:424: DB::ProjectionsDescription::remove(String const&, bool) @ 0x000000003036387c 6. ./build_docker/./src/Storages/AlterCommands.cpp:860: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302baa62 7. ./build_docker/./src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000302c5739 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3533: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc6da9 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:45:25.898915 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:26.016736 [ 8431 ] {76e7447d-c50b-4465-a89d-0280a08084a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1346, line 1351) (in query: SELECT toDecimal256OrNull();) 2025.06.13 15:45:26.043485 [ 5110 ] {0c3c1bc0-1798-4bb7-804d-438028be795f} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal64(0, 1). (ILLEGAL_DIVISION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 44, line 71) (in query: SELECT 1 / toDecimal64(0, 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001a072a98 6. DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, long, long, DB::Decimal, DB::Decimal>(long, long, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000001a43fe67 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43f1ad 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43ecc3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43ea6a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a4318ff 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a430461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:45:26.113422 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:26.114116 [ 5110 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal64(0, 1). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001a072a98 6. DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, long, long, DB::Decimal, DB::Decimal>(long, long, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000001a43fe67 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43f1ad 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43ecc3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43ea6a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a4318ff 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a430461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:45:26.132195 [ 5978 ] {c85a1dfe-1b91-40ec-8b92-987d21f28758} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1087, line 1089) (in query: SELECT quantilesTiming(-1);) 2025.06.13 15:45:26.146113 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:26.238725 [ 5978 ] {c7660270-ae31-413e-8f3c-d4d22b33ff05} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1088, line 1090) (in query: SELECT quantilesTimingWeighted(-1);) 2025.06.13 15:45:26.251704 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function for calculation of multiple quantiles require at least one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:26.260089 [ 8431 ] {4eeb56b0-4d7d-4c01-960e-40ae583833b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1347, line 1352) (in query: SELECT toDecimal256OrZero();) 2025.06.13 15:45:26.292692 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:26.358077 [ 5978 ] {d17e802a-f4eb-4884-980b-3fa4cc9d84d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 1, should be 0: In scope SELECT queryID(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1089, line 1091) (in query: SELECT queryID(-1);) 2025.06.13 15:45:26.373887 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 1, should be 0: In scope SELECT queryID(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:26.382796 [ 8431 ] {cd532d94-8cd1-4b0c-9d43-e2937f197007} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1348, line 1353) (in query: SELECT toDecimal32();) 2025.06.13 15:45:26.405048 [ 5110 ] {cddd77dc-356f-4c25-8014-0eef8afc38ab} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal128(0, 2). (ILLEGAL_DIVISION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 45, line 72) (in query: SELECT 1 / toDecimal128(0, 2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a092a01 6. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, false>::applyScaledDiv(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a092b61 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::ColumnVector, DB::ColumnDecimal>>>(DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal>> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a44089a 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a4401e3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000001a43ff8a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43193f 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a430461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:45:26.406787 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:26.427889 [ 5110 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal128(0, 2). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a092a01 6. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, false>::applyScaledDiv(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a092b61 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::ColumnVector, DB::ColumnDecimal>>>(DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal>> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a44089a 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a4401e3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000001a43ff8a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43193f 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a430461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:45:26.666102 [ 5978 ] {d017b837-6649-4275-95fd-55f02875ed52} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function queryString: In scope SELECT queryString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1090, line 1092) (in query: SELECT queryString(-1);) 2025.06.13 15:45:26.671685 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function queryString: In scope SELECT queryString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:26.679656 [ 8431 ] {96a543a6-69e4-48ae-88f3-4f3985a7ef06} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1349, line 1354) (in query: SELECT toDecimal32OrDefault();) 2025.06.13 15:45:26.688708 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:26.728398 [ 5110 ] {4782714b-53ab-4033-a37e-f5fac37b2c5a} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal32(0, 3). (ILLEGAL_DIVISION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 46, line 73) (in query: SELECT 0 / toDecimal32(0, 3);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000001a08c356 6. DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, int, int, DB::Decimal, DB::Decimal>(int, int, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000001a43e95c 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43da5b 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43d7a3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43d54a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a4318bf 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a430461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:45:26.752819 [ 5110 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal32(0, 3). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000001a08c356 6. DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, int, int, DB::Decimal, DB::Decimal>(int, int, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000001a43e95c 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43da5b 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43d7a3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43d54a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a4318bf 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a430461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:45:26.808893 [ 5978 ] {383478b3-f54f-4231-858c-80c3f469d556} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function queryStringAndFragment: In scope SELECT queryStringAndFragment(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1091, line 1093) (in query: SELECT queryStringAndFragment(-1);) 2025.06.13 15:45:26.822243 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function queryStringAndFragment: In scope SELECT queryStringAndFragment(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:26.844156 [ 8431 ] {e0a3e004-c025-4e73-91f8-ea542c45cff4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1350, line 1355) (in query: SELECT toDecimal32OrNull();) 2025.06.13 15:45:26.854319 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:26.958153 [ 5978 ] {19298882-7142-481c-9569-98ae919eb108} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 1, should be 0: In scope SELECT query_id(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1092, line 1094) (in query: SELECT query_id(-1);) 2025.06.13 15:45:26.966906 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 1, should be 0: In scope SELECT query_id(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:27.007860 [ 5110 ] {f21d72a5-7d5b-435e-a0b8-fbde61fcff72} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal64(0, 4). (ILLEGAL_DIVISION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 47, line 74) (in query: SELECT 0 / toDecimal64(0, 4);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001a072a98 6. DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, long, long, DB::Decimal, DB::Decimal>(long, long, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000001a43fe67 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43f1ad 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43ecc3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43ea6a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a4318ff 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a430461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:45:27.027408 [ 8431 ] {3f3cad31-e444-46ac-8e88-2f08cf48688a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1351, line 1356) (in query: SELECT toDecimal32OrZero();) 2025.06.13 15:45:27.029417 [ 5110 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal64(0, 4). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001a072a98 6. DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, long, long, DB::Decimal, DB::Decimal>(long, long, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000001a43fe67 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43f1ad 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a43ecc3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>(auto const&, auto const&) const @ 0x000000001a43ea6a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a4318ff 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a430461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:45:27.040557 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:27.163215 [ 8101 ] {84915607-c47f-47a3-8740-c9fa7a747004} executeQuery: Code: 43. DB::Exception: The timezone argument of function toMonday is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMonday(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 77, line 77) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toMonday(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:27.163400 [ 5110 ] {908eb9a0-08e7-41d9-b492-167a1329cc94} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal128(0, 5). (ILLEGAL_DIVISION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 48, line 75) (in query: SELECT 0 / toDecimal128(0, 5);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a092a01 6. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, false>::applyScaledDiv(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a092b61 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::ColumnVector, DB::ColumnDecimal>>>(DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal>> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a44089a 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a4401e3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000001a43ff8a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43193f 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a430461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:45:27.175109 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toMonday is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMonday(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:27.184716 [ 8431 ] {da973a96-aa89-420f-9a21-75981e91e50c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1352, line 1357) (in query: SELECT toDecimal64();) 2025.06.13 15:45:27.184818 [ 18380 ] {cb535d45-ef86-4ed9-9df8-c0d59dfc54a6} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38292) (comment: 02423_ddl_for_opentelemetry.sh) (query 1, line 1) (in query: CREATE TABLE test_11.ddl_test_for_opentelemetry ON CLUSTER test_11 (`id` UInt64) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 16095, 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 = 175104615, compact_parts_max_bytes_to_buffer = 253899654, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 13909844, merge_max_block_size = 4819, old_parts_lifetime = 339., prefer_fetch_merged_part_size_threshold = 1924087614, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3744371766, index_granularity_bytes = 14743602, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 15, 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 = 58084, primary_key_compress_block_size = 61446, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:27.185966 [ 5110 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal128(0, 5). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a092a01 6. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, false>::applyScaledDiv(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a092b61 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::ColumnVector, DB::ColumnDecimal>>>(DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal>> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a44089a 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a4401e3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000001a43ff8a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43193f 11. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a430461 12. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 13. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 14. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 15. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:45:27.197231 [ 18380 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:27.206202 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:27.359115 [ 8431 ] {a417f45f-a359-444f-8a29-222e909dd27a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1353, line 1358) (in query: SELECT toDecimal64OrDefault();) 2025.06.13 15:45:27.378861 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:27.412592 [ 5110 ] {ccaf2882-a1f2-4895-bc46-30e842217a63} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal32(0, 0) / toInt8(0). (ILLEGAL_DIVISION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 49, line 77) (in query: SELECT toDecimal32(0, 0) / toInt8(0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000001a08c356 6. DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, int, int, DB::Decimal, DB::Decimal>(int, int, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000001a53795b 7. _ZNK2DB24FunctionBinaryArithmeticINS_18DivideFloatingImplENS_10NameDivideELb1ELb1ELb0EE25executeNumericWithDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberIDB8_EES8_S8_SB_NS_13ColumnDecimalIS7_EENS_12ColumnVectorISA_EEEEN3COWINS_7IColumnEE13immutable_ptrISH_EERKT2_RKT3_PKNS_11ColumnConstEST_PKT4_PKT5_mPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEE @ 0x000000001a53d953 8. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber<_BitInt(8)>>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a53d6c3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeNumber<_BitInt(8)>>(auto const&, auto const&) const @ 0x000000001a53d46a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a5357dc 11. auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000001a430eb2 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43091f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:27.465775 [ 5110 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal32(0, 0) / toInt8(0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000001a08c356 6. DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, int, int, DB::Decimal, DB::Decimal>(int, int, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000001a53795b 7. _ZNK2DB24FunctionBinaryArithmeticINS_18DivideFloatingImplENS_10NameDivideELb1ELb1ELb0EE25executeNumericWithDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberIDB8_EES8_S8_SB_NS_13ColumnDecimalIS7_EENS_12ColumnVectorISA_EEEEN3COWINS_7IColumnEE13immutable_ptrISH_EERKT2_RKT3_PKNS_11ColumnConstEST_PKT4_PKT5_mPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEE @ 0x000000001a53d953 8. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber<_BitInt(8)>>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a53d6c3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeNumber<_BitInt(8)>>(auto const&, auto const&) const @ 0x000000001a53d46a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a5357dc 11. auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000001a430eb2 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43091f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:27.477849 [ 8431 ] {5d26d69e-380e-4c42-b664-cf35c5783571} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1354, line 1359) (in query: SELECT toDecimal64OrNull();) 2025.06.13 15:45:27.512012 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:27.545220 [ 5112 ] {a8f6cf27-33d5-4539-8230-b30c91585101} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40798) (comment: 00956_http_prepared_statements.sh) (in query: CREATE TABLE ps (i UInt8, s String, d Date) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:27.556165 [ 5112 ] {a8f6cf27-33d5-4539-8230-b30c91585101} DynamicQueryHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:45:27.618417 [ 8431 ] {c1825a21-092c-4b3d-9f0c-fb0da82f27aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1355, line 1360) (in query: SELECT toDecimal64OrZero();) 2025.06.13 15:45:27.628055 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:27.674537 [ 5110 ] {df9fdd44-ccac-4ebf-9f50-92a39e265b03} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal64(0, 1) / toInt32(0). (ILLEGAL_DIVISION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 50, line 78) (in query: SELECT toDecimal64(0, 1) / toInt32(0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001a072a98 6. DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, long, long, DB::Decimal, DB::Decimal>(long, long, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000001a54f440 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::ColumnDecimal>, DB::ColumnVector>(DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a557870 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a5575c3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001a55736a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a54d3bc 11. auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000001a430f12 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43095f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:27.694713 [ 5110 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal64(0, 1) / toInt32(0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000001a072a98 6. DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, long, long, DB::Decimal, DB::Decimal>(long, long, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000001a54f440 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::ColumnDecimal>, DB::ColumnVector>(DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a557870 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a5575c3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001a55736a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a54d3bc 11. auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000001a430f12 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43095f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:27.724626 [ 5163 ] {187b6412-098d-4ef0-8551-dd92b1c536fe} executeQuery: Code: 475. DB::Exception: ORDER BY containing the same expression with and without WITH FILL modifier is not supported. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38318) (comment: 03015_with_fill_invalid_expression.sql) (query 1, line 1) (in query: select number as x, number + 1 as y from numbers(5) where number % 3 == 1 order by y, x with fill from 1 to 4, y with fill from 2 to 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:287: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x00000000320f5e7c 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], bool const&, std::allocator, 0>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x00000000320f08e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x00000000320f0714 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x00000000320ef6dd 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c36b57b 10. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002c36b2e5 11. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000320ee832 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000032115740 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:45:27.728343 [ 6193 ] {52b83b41-c725-4bad-b9e6-a06c8efb13bb} executeQuery: Code: 60. DB::Exception: Table test_7.ps does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40802) (comment: 00956_http_prepared_statements.sh) (in query: INSERT INTO ps VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:45:27.734186 [ 8431 ] {f2977e20-9883-4c26-be48-2cb99265509f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 0, should be 2: In scope SELECT toDecimalString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1356, line 1361) (in query: SELECT toDecimalString();) 2025.06.13 15:45:27.734614 [ 6193 ] {52b83b41-c725-4bad-b9e6-a06c8efb13bb} DynamicQueryHandler: Code: 60. DB::Exception: Table test_7.ps does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:45:27.747466 [ 5163 ] {} TCPHandler: Code: 475. DB::Exception: ORDER BY containing the same expression with and without WITH FILL modifier is not supported. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:287: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x00000000320f5e7c 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], bool const&, std::allocator, 0>(std::allocator, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x00000000320f08e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x00000000320f0714 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x00000000320ef6dd 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c36b57b 10. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002c36b2e5 11. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000320ee832 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000032115740 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:45:27.755633 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 0, should be 2: In scope SELECT toDecimalString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:27.857836 [ 8431 ] {a2167a47-5f7f-4af5-93b5-7fbc65f6c4f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 0, should be 2: In scope SELECT toFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1357, line 1362) (in query: SELECT toFixedString();) 2025.06.13 15:45:27.867127 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 0, should be 2: In scope SELECT toFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:27.966232 [ 5110 ] {d756e511-4d58-42c3-88da-f02fa56062d1} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal128(0, 2) / toInt64(0). (ILLEGAL_DIVISION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 51, line 79) (in query: SELECT toDecimal128(0, 2) / toInt64(0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a092a01 6. DB::Decimal> DB::FunctionBinaryArithmetic::helperInvokeEither>, false>, DB::impl_::DecimalBinaryOperation>, true>, DB::Decimal>, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::Decimal>, DB::Decimal>>(wide::integer<128ul, int>, wide::integer<128ul, int>, DB::Decimal>, DB::Decimal>) const requires !is_decimal && !is_decimal @ 0x000000001a566f3b 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::ColumnDecimal>>, DB::ColumnVector>(DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal>> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a57119c 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a570ea3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001a570c4a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a564cfc 11. auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const @ 0x000000001a430f72 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43099f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:27.976956 [ 5978 ] {4d42b3b0-70d7-4525-bf1e-1e7317bf8952} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function randBernoulli, expected Float64 or integer: In scope SELECT randBernoulli(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1097, line 1099) (in query: SELECT randBernoulli(-1);) 2025.06.13 15:45:27.981325 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function randBernoulli, expected Float64 or integer: In scope SELECT randBernoulli(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:27.987052 [ 3895 ] {9e8288b6-41ee-4a95-beff-850f66b09572} executeQuery: Code: 60. DB::Exception: Table test_7.ps does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40806) (comment: 00956_http_prepared_statements.sh) (in query: INSERT INTO ps VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:45:27.991609 [ 5110 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal128(0, 2) / toInt64(0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000001a092a01 6. DB::Decimal> DB::FunctionBinaryArithmetic::helperInvokeEither>, false>, DB::impl_::DecimalBinaryOperation>, true>, DB::Decimal>, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::Decimal>, DB::Decimal>>(wide::integer<128ul, int>, wide::integer<128ul, int>, DB::Decimal>, DB::Decimal>) const requires !is_decimal && !is_decimal @ 0x000000001a566f3b 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::ColumnDecimal>>, DB::ColumnVector>(DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal>> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a57119c 8. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a570ea3 9. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001a570c4a 10. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a564cfc 11. auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const @ 0x000000001a430f72 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a43099f 13. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001a42b8c3 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a42982c 15. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a427ba8 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:27.992043 [ 3895 ] {9e8288b6-41ee-4a95-beff-850f66b09572} DynamicQueryHandler: Code: 60. DB::Exception: Table test_7.ps does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:45:28.012230 [ 8431 ] {58b7c68c-5e0d-4d3c-92b6-ad4131f6e2de} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32'. Expected 1 argument, got 0 arguments: In scope SELECT toFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1358, line 1363) (in query: SELECT toFloat32();) 2025.06.13 15:45:28.093078 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32'. Expected 1 argument, got 0 arguments: In scope SELECT toFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:28.099123 [ 6234 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:28.109643 [ 6234 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:45:28.110364 [ 6621 ] {4959d369-9a95-4b4d-b649-91d2734c6296} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_v1krk9sf.t_json_async_insert (data) FORMAT JSONAsObject' with query id 67e889c5-7ce1-4a9a-ac94-8aee7c6ffab2. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) 2025.06.13 15:45:28.116246 [ 5978 ] {924f5ea5-6b84-415a-a192-67f6e61fe366} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randBinomial. Should be 2 or 3: In scope SELECT randBinomial(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1098, line 1100) (in query: SELECT randBinomial(-1);) 2025.06.13 15:45:28.125291 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randBinomial. Should be 2 or 3: In scope SELECT randBinomial(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:28.153595 [ 5112 ] {67e889c5-7ce1-4a9a-ac94-8aee7c6ffab2} executeQuery: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38340) (comment: 02421_new_type_json_async_insert.sh) (query 1, line 1) (in query: INSERT INTO t_json_async_insert FORMAT JSONAsObject ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeObject(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x000000002c5b8378 6. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:393: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5b7dc5 7. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:52: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031a697b6 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 12. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x000000003183da52 13. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003183d525 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fe2df 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:45:28.164625 [ 5112 ] {} TCPHandler: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeObject(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x000000002c5b8378 6. ./build_docker/./src/DataTypes/Serializations/SerializationJSON.cpp:393: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c5b7dc5 7. ./build_docker/./src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:52: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031a697b6 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 12. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x000000003183da52 13. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003183d525 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fe2df 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:45:28.229628 [ 8431 ] {bb460d5d-d7c1-4ce4-bf3d-75ee0358af0e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toFloat32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1359, line 1364) (in query: SELECT toFloat32OrDefault();) 2025.06.13 15:45:28.235749 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toFloat32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:28.372193 [ 8101 ] {0f55526b-08d7-426b-8983-5cd4ee2ea327} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 82, line 82) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:28.372686 [ 6193 ] {939332d0-4bf2-4979-9c2f-f66ba292a616} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ps' in scope SELECT * FROM ps WHERE i = _CAST(1, 'UInt8') ORDER BY i ASC, s ASC, d ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40812) (comment: 00956_http_prepared_statements.sh) (in query: SELECT * FROM ps WHERE i = _CAST(1, 'UInt8') ORDER BY i ASC, s ASC, d ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:45:28.385212 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:28.390842 [ 6193 ] {939332d0-4bf2-4979-9c2f-f66ba292a616} DynamicQueryHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ps' in scope SELECT * FROM ps WHERE i = _CAST(1, 'UInt8') ORDER BY i ASC, s ASC, d ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:45:28.431009 [ 8431 ] {290167f1-bb5a-41be-a7ca-7bfcfb4f41f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1360, line 1365) (in query: SELECT toFloat32OrNull();) 2025.06.13 15:45:28.459877 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:28.488880 [ 5978 ] {f610eff2-d7cb-4434-8951-be5039e79dd0} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function randChiSquared, expected Float64 or integer: In scope SELECT randChiSquared(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1100, line 1102) (in query: SELECT randChiSquared(-1);) 2025.06.13 15:45:28.527105 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function randChiSquared, expected Float64 or integer: In scope SELECT randChiSquared(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:28.534437 [ 8101 ] {036abb41-9018-4429-9937-c4dc11485cb9} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 83, line 83) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:28.549739 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:28.582689 [ 8431 ] {edfc4413-28e1-4b2e-91a2-eb3e95cf7a9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1361, line 1366) (in query: SELECT toFloat32OrZero();) 2025.06.13 15:45:28.591672 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:28.686183 [ 3931 ] {061a1a61-fa3d-4581-bbfd-28139fbde6dc} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ps' in scope SELECT * FROM ps WHERE s = 'Hello, world' ORDER BY i ASC, s ASC, d ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40814) (comment: 00956_http_prepared_statements.sh) (in query: SELECT * FROM ps WHERE s = 'Hello, world' ORDER BY i ASC, s ASC, d ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:45:28.698604 [ 3931 ] {061a1a61-fa3d-4581-bbfd-28139fbde6dc} DynamicQueryHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ps' in scope SELECT * FROM ps WHERE s = 'Hello, world' ORDER BY i ASC, s ASC, d ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:45:28.699112 [ 8101 ] {450a44a7-74cd-4a82-b86f-a06e035d6d28} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 84, line 84) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:28.710769 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:28.790338 [ 8431 ] {f4ecd31b-2cca-437f-9dc4-ea498b945c87} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64'. Expected 1 argument, got 0 arguments: In scope SELECT toFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1362, line 1367) (in query: SELECT toFloat64();) 2025.06.13 15:45:28.808150 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64'. Expected 1 argument, got 0 arguments: In scope SELECT toFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:28.845491 [ 5978 ] {5adc7ef1-27b5-4e71-980d-5401d0bcd598} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function randExponential, expected Float64 or integer: In scope SELECT randExponential(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1102, line 1104) (in query: SELECT randExponential(-1);) 2025.06.13 15:45:28.858884 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function randExponential, expected Float64 or integer: In scope SELECT randExponential(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:28.932819 [ 8431 ] {83bf26dc-64db-4f34-9c29-26e006b0f4c1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toFloat64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1363, line 1368) (in query: SELECT toFloat64OrDefault();) 2025.06.13 15:45:28.966812 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toFloat64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:28.972086 [ 7755 ] {c0c2f26b-0dff-4a89-9f6d-b60011c36d43} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ps' in scope SELECT * FROM ps WHERE d = _CAST(18041, 'Date') ORDER BY i ASC, s ASC, d ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40826) (comment: 00956_http_prepared_statements.sh) (in query: SELECT * FROM ps WHERE d = _CAST(18041, 'Date') ORDER BY i ASC, s ASC, d ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:45:28.973897 [ 5978 ] {c9492fa1-c0d2-4aff-817b-e95b19257b7e} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randFisherF. Should be 2 or 3: In scope SELECT randFisherF(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1103, line 1105) (in query: SELECT randFisherF(-1);) 2025.06.13 15:45:28.985606 [ 7755 ] {c0c2f26b-0dff-4a89-9f6d-b60011c36d43} DynamicQueryHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ps' in scope SELECT * FROM ps WHERE d = _CAST(18041, 'Date') ORDER BY i ASC, s ASC, d ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:45:28.988482 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randFisherF. Should be 2 or 3: In scope SELECT randFisherF(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:29.052716 [ 8431 ] {a331c292-b2c7-4e33-9969-5b1fc87e747a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1364, line 1369) (in query: SELECT toFloat64OrNull();) 2025.06.13 15:45:29.088185 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:29.095173 [ 5978 ] {5d349cf4-4389-454b-bd8a-a65c307d6027} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randLogNormal. Should be 2 or 3: In scope SELECT randLogNormal(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1104, line 1106) (in query: SELECT randLogNormal(-1);) 2025.06.13 15:45:29.121818 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randLogNormal. Should be 2 or 3: In scope SELECT randLogNormal(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:29.170705 [ 8431 ] {999dfc34-e9c8-47ec-b7d6-9b7f5568221c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1365, line 1370) (in query: SELECT toFloat64OrZero();) 2025.06.13 15:45:29.183722 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:29.228910 [ 7755 ] {1871acc1-6c19-40b4-90d2-a70fac0c78ff} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ps' in scope SELECT * FROM ps WHERE (i = _CAST(2, 'UInt8')) AND (s = 'test') ORDER BY i ASC, s ASC, d ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40830) (comment: 00956_http_prepared_statements.sh) (in query: SELECT * FROM ps WHERE (i = _CAST(2, 'UInt8')) AND (s = 'test') ORDER BY i ASC, s ASC, d ASC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:45:29.232561 [ 5978 ] {3cfe7f25-8da2-4c7b-916a-6e1da687af5c} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randNegativeBinomial. Should be 2 or 3: In scope SELECT randNegativeBinomial(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1105, line 1107) (in query: SELECT randNegativeBinomial(-1);) 2025.06.13 15:45:29.251909 [ 7755 ] {1871acc1-6c19-40b4-90d2-a70fac0c78ff} DynamicQueryHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ps' in scope SELECT * FROM ps WHERE (i = _CAST(2, 'UInt8')) AND (s = 'test') ORDER BY i ASC, s ASC, d ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:45:29.252828 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randNegativeBinomial. Should be 2 or 3: In scope SELECT randNegativeBinomial(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:29.331073 [ 5005 ] {b58ed3c2-0764-4944-9f1a-72f53e3b2071} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 51.51 KiB (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38332) (comment: 02423_ddl_for_opentelemetry.sh) (query 2, line 4) (in query: SELECT count() FROM system.opentelemetry_span_log WHERE finish_date >= yesterday() AND lower(hex(trace_id)) = '51566718380047939a465a0fb3c0852e' AND operation_name like 'TCPHandler' ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6ab404 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6bc5ae 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d8bba4 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d85ecd 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:29.351336 [ 5005 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 51.51 KiB (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x000000002d6ab404 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000002d6bc5ae 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000031d8bba4 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000031d85ecd 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:45:29.373807 [ 8431 ] {c9961239-8af2-4e77-a4e0-76abf659c71f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 0, should be 1 or 2: In scope SELECT toHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1366, line 1371) (in query: SELECT toHour();) 2025.06.13 15:45:29.392331 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 0, should be 1 or 2: In scope SELECT toHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:29.406066 [ 5978 ] {e8c321d3-c064-41f4-88e1-4bb39ade86fa} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randNormal. Should be 2 or 3: In scope SELECT randNormal(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1106, line 1108) (in query: SELECT randNormal(-1);) 2025.06.13 15:45:29.420146 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randNormal. Should be 2 or 3: In scope SELECT randNormal(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:29.476590 [ 5110 ] {e8fa7b50-0de8-4ef2-b3b0-3736fc659e1b} executeQuery: Code: 407. DB::Exception: Overflow during decimal division: In scope SELECT toDecimal128(1, 38) / toDecimal128(1, 1) SETTINGS decimal_check_overflow = 1. (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 56, line 87) (in query: SELECT toDecimal128(1, 38) / toDecimal128(1, 1) SETTINGS decimal_check_overflow=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000001a611d9e 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a60f07f 7. auto bool DB::FunctionBinaryArithmetic::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const @ 0x000000001a5eabb2 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a5ea5df 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a5e9468 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a06cd11 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:45:29.505362 [ 8431 ] {9af1d895-a5ae-48bb-8c9d-dbc5a197d92b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4'. Expected 1 argument, got 0 arguments: In scope SELECT toIPv4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1367, line 1372) (in query: SELECT toIPv4();) 2025.06.13 15:45:29.508725 [ 5110 ] {} TCPHandler: Code: 407. DB::Exception: Overflow during decimal division: In scope SELECT toDecimal128(1, 38) / toDecimal128(1, 1) SETTINGS decimal_check_overflow = 1. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000001a611d9e 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a60f07f 7. auto bool DB::FunctionBinaryArithmetic::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const @ 0x000000001a5eabb2 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a5ea5df 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a5e9468 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a06cd11 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:45:29.511640 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4'. Expected 1 argument, got 0 arguments: In scope SELECT toIPv4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:29.541467 [ 9636 ] {f3afd969-c459-40c6-86c3-1e8aa3bf3515} executeQuery: Code: 60. DB::Exception: Table test_7.ps does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40836) (comment: 00956_http_prepared_statements.sh) (in query: DROP TABLE ps), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:45:29.544326 [ 9636 ] {f3afd969-c459-40c6-86c3-1e8aa3bf3515} DynamicQueryHandler: Code: 60. DB::Exception: Table test_7.ps does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:45:29.595739 [ 5978 ] {539cd02a-5320-42d7-ab77-77a6c597e53f} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function randPoisson, expected Float64 or integer: In scope SELECT randPoisson(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1107, line 1109) (in query: SELECT randPoisson(-1);) 2025.06.13 15:45:29.600001 [ 8431 ] {4b40c19a-4529-4857-8a12-ae5cc8c77646} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toIPv4OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1368, line 1373) (in query: SELECT toIPv4OrDefault();) 2025.06.13 15:45:29.617734 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function randPoisson, expected Float64 or integer: In scope SELECT randPoisson(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:29.618314 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toIPv4OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:29.696217 [ 8431 ] {7ed94602-c2b2-4939-962d-ceb102907cac} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv4OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1369, line 1374) (in query: SELECT toIPv4OrNull();) 2025.06.13 15:45:29.705453 [ 5978 ] {13e99ce6-cfe7-4af3-9ccc-91cebf57ca6d} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function randStudentT, expected Float64 or integer: In scope SELECT randStudentT(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1108, line 1110) (in query: SELECT randStudentT(-1);) 2025.06.13 15:45:29.705876 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv4OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:29.739856 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function randStudentT, expected Float64 or integer: In scope SELECT randStudentT(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:29.821178 [ 8431 ] {365809a7-7d05-48be-8479-1a50ce95a14b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv4OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1370, line 1375) (in query: SELECT toIPv4OrZero();) 2025.06.13 15:45:29.835897 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv4OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:29.836543 [ 5978 ] {be2cd2ef-fee3-43f9-837c-a30e4592d5c6} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randUniform. Should be 2 or 3: In scope SELECT randUniform(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1109, line 1111) (in query: SELECT randUniform(-1);) 2025.06.13 15:45:29.842569 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randUniform. Should be 2 or 3: In scope SELECT randUniform(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:29.925272 [ 8431 ] {721cea26-a1bc-459f-8001-986c1b5036ab} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6'. Expected 1 argument, got 0 arguments: In scope SELECT toIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1371, line 1376) (in query: SELECT toIPv6();) 2025.06.13 15:45:29.933643 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6'. Expected 1 argument, got 0 arguments: In scope SELECT toIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:29.935854 [ 5978 ] {fb362193-3b96-45c6-abb7-2a3caab5e109} executeQuery: Code: 43. DB::Exception: First argument for function randomFixedString must be unsigned integer: In scope SELECT randomFixedString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1110, line 1112) (in query: SELECT randomFixedString(-1);) 2025.06.13 15:45:29.942808 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function randomFixedString must be unsigned integer: In scope SELECT randomFixedString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:30.034352 [ 8431 ] {66d3bc29-5a29-4e37-ac0f-5bc9366d5ec2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toIPv6OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1372, line 1377) (in query: SELECT toIPv6OrDefault();) 2025.06.13 15:45:30.045440 [ 3895 ] {80315996-48de-480c-93cd-bde727907015} executeQuery: Code: 291. DB::Exception: Path 'data_*_{_partition_id}.csv' contains globs, so the table is in readonly mode. (DATABASE_ACCESS_DENIED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38444) (comment: 03037_s3_write_to_globbed_partitioned_path.sql) (query 1, line 3) (in query: insert into function s3('http://localhost:11111/test/data_*_{_partition_id}.csv') partition by number % 3 select * from numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:427: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002b524d78 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031ef648f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dcdd134 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dcdf787 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dce12f7 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5edc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:45:30.055531 [ 3895 ] {} TCPHandler: Code: 291. DB::Exception: Path 'data_*_{_partition_id}.csv' contains globs, so the table is in readonly mode. (DATABASE_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:427: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002b524d78 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:626: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031ef648f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dcdd134 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dcdf787 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dce12f7 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5edc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:45:30.062207 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toIPv6OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:30.111405 [ 5978 ] {740fdab9-33a5-4ea2-8fe6-7abfb7c1a362} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-1). (TOO_LARGE_STRING_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1111, line 1113) (in query: SELECT randomPrintableASCII(-1);) 2025.06.13 15:45:30.218827 [ 5978 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-1). (TOO_LARGE_STRING_SIZE) 2025.06.13 15:45:30.315974 [ 8431 ] {41a700ac-88db-4b32-ac88-a4996339ecc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv6OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1373, line 1378) (in query: SELECT toIPv6OrNull();) 2025.06.13 15:45:30.322766 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv6OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:30.337522 [ 5978 ] {bc52dcc1-9eca-47e5-b859-79a59fc4702d} executeQuery: Code: 131. DB::Exception: Too large string size in function randomString: In scope SELECT randomString(-1). (TOO_LARGE_STRING_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1112, line 1114) (in query: SELECT randomString(-1);) 2025.06.13 15:45:30.343096 [ 5978 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomString: In scope SELECT randomString(-1). (TOO_LARGE_STRING_SIZE) 2025.06.13 15:45:30.413865 [ 8101 ] {925b31d3-e049-45e0-ad49-e362a90b06b2} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 92, line 92) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfHour(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:30.424564 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:30.515562 [ 8431 ] {57a92ee7-1e1c-402f-af02-c50b2eb03146} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv6OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1374, line 1379) (in query: SELECT toIPv6OrZero();) 2025.06.13 15:45:30.529044 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv6OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:30.559403 [ 5978 ] {a1c5b21b-2c85-4907-a70e-e79a07f09801} executeQuery: Code: 131. DB::Exception: Too large string size in function randomStringUTF8: In scope SELECT randomStringUTF8(-1). (TOO_LARGE_STRING_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1113, line 1115) (in query: SELECT randomStringUTF8(-1);) 2025.06.13 15:45:30.559719 [ 5110 ] {9fb55bcb-f22e-4df1-8168-8898b2be8fef} executeQuery: Code: 407. DB::Exception: Overflow during decimal division: In scope SELECT toDecimal128(1, 20) / toDecimal128(1, 19) SETTINGS decimal_check_overflow = 1. (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46766) (comment: 00700_decimal_arithm.sql) (query 60, line 92) (in query: SELECT toDecimal128(1, 20) / toDecimal128(1, 19) SETTINGS decimal_check_overflow=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000001a611d9e 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a60f07f 7. auto bool DB::FunctionBinaryArithmetic::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const @ 0x000000001a5eabb2 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a5ea5df 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a5e9468 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a06cd11 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:45:30.593310 [ 5110 ] {} TCPHandler: Code: 407. DB::Exception: Overflow during decimal division: In scope SELECT toDecimal128(1, 20) / toDecimal128(1, 19) SETTINGS decimal_check_overflow = 1. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000001a611d9e 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a60f07f 7. auto bool DB::FunctionBinaryArithmetic::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const @ 0x000000001a5eabb2 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001a5ea5df 9. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a5e9468 10. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a06cd11 11. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:45:30.627319 [ 5978 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomStringUTF8: In scope SELECT randomStringUTF8(-1). (TOO_LARGE_STRING_SIZE) 2025.06.13 15:45:30.677488 [ 8431 ] {cbd24956-326f-4b83-9b75-38a6215ded6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toISOWeek doesn't match: passed 0, should be 1 or 2: In scope SELECT toISOWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1375, line 1380) (in query: SELECT toISOWeek();) 2025.06.13 15:45:30.677628 [ 5978 ] {a80b4d81-ef9e-4559-84f4-2cbbad526dbb} executeQuery: Code: 69. DB::Exception: A call to function range overflows, only support positive values when only end is provided: In scope SELECT range(-1). (ARGUMENT_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1114, line 1116) (in query: SELECT range(-1);) 2025.06.13 15:45:30.685231 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toISOWeek doesn't match: passed 0, should be 1 or 2: In scope SELECT toISOWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:30.687817 [ 5978 ] {} TCPHandler: Code: 69. DB::Exception: A call to function range overflows, only support positive values when only end is provided: In scope SELECT range(-1). (ARGUMENT_OUT_OF_BOUND) 2025.06.13 15:45:30.763539 [ 8431 ] {772293c8-8601-466a-9d79-46c89d28db8a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toISOYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toISOYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1376, line 1381) (in query: SELECT toISOYear();) 2025.06.13 15:45:30.777892 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toISOYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toISOYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:30.869159 [ 5978 ] {fd8da9db-f178-4915-8742-d937024830b9} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1115, line 1117) (in query: SELECT rank(-1);) 2025.06.13 15:45:30.873859 [ 8431 ] {58d6925c-bcb7-4c08-9922-ed90775986d3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128'. Expected 1 argument, got 0 arguments: In scope SELECT toInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1377, line 1382) (in query: SELECT toInt128();) 2025.06.13 15:45:30.883206 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:45:30.883500 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128'. Expected 1 argument, got 0 arguments: In scope SELECT toInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:30.900199 [ 18510 ] {9fc56378-139c-474e-9de8-7dc6d71a5090} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38554) (comment: 02690_subquery_identifiers.sql) (query 2, line 3) (in query: CREATE TABLE t_str (`creation_time` String) ENGINE = MergeTree PARTITION BY creation_time ORDER BY creation_time SETTINGS index_granularity = 55809, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 23, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 73078562, compact_parts_max_granules_to_buffer = 47, compact_parts_merge_max_bytes_to_prefetch_part = 25335484, merge_max_block_size = 4843, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 23619696, 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 = true, marks_compress_block_size = 89381, primary_key_compress_block_size = 63718, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:45:30.944566 [ 18510 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:45:30.972423 [ 5978 ] {f2051159-3a83-4ccd-a4ba-9912b8782570} executeQuery: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1116, line 1118) (in query: SELECT rankCorr(-1);) 2025.06.13 15:45:30.987179 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:31.027540 [ 8431 ] {f9b9bc04-22da-4951-9466-6cefb96d0ed3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1378, line 1383) (in query: SELECT toInt128OrDefault();) 2025.06.13 15:45:31.031839 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:31.075152 [ 5978 ] {1e17f802-3943-441f-8545-0feef43ed248} executeQuery: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTLineString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1117, line 1119) (in query: SELECT readWKTLineString(-1);) 2025.06.13 15:45:31.100557 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTLineString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:31.151420 [ 8431 ] {f519a110-d401-4b6c-9cea-59576beb4802} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1379, line 1384) (in query: SELECT toInt128OrNull();) 2025.06.13 15:45:31.173598 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:31.208657 [ 5978 ] {e7219200-70f1-4df5-8e74-c770b717495f} executeQuery: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTMultiLineString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1118, line 1120) (in query: SELECT readWKTMultiLineString(-1);) 2025.06.13 15:45:31.229074 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTMultiLineString(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:31.252675 [ 8431 ] {050aabc0-1dba-4a9e-ab11-53cf013d3a6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1380, line 1385) (in query: SELECT toInt128OrZero();) 2025.06.13 15:45:31.270157 [ 8101 ] {4b7de6fb-1029-4d5c-a988-272dc255f0e2} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 97, line 97) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfMinute(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:31.270987 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:31.290568 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:31.321930 [ 5978 ] {e075ac09-e3de-4962-8b3c-8cbb066ca52e} executeQuery: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTMultiPolygon(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1119, line 1121) (in query: SELECT readWKTMultiPolygon(-1);) 2025.06.13 15:45:31.364321 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTMultiPolygon(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:31.374041 [ 8431 ] {985ef75f-9fa8-499d-845e-ec4729ca76bb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16'. Expected 1 argument, got 0 arguments: In scope SELECT toInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1381, line 1386) (in query: SELECT toInt16();) 2025.06.13 15:45:31.400828 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16'. Expected 1 argument, got 0 arguments: In scope SELECT toInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:31.407439 [ 5978 ] {28c93aca-75a8-4d88-bb0e-b12991fef24e} executeQuery: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTPoint(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1120, line 1122) (in query: SELECT readWKTPoint(-1);) 2025.06.13 15:45:31.424310 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTPoint(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:31.535003 [ 8431 ] {a24f3303-fbea-4869-b433-aa1337baf5c9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1382, line 1387) (in query: SELECT toInt16OrDefault();) 2025.06.13 15:45:31.535501 [ 5978 ] {c7d15a7d-27c1-42e7-83e2-584552ec83ad} executeQuery: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTPolygon(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1121, line 1123) (in query: SELECT readWKTPolygon(-1);) 2025.06.13 15:45:31.548587 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTPolygon(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:31.557022 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:31.624444 [ 18602 ] {ab9ee980-a29c-46e3-9cd4-34499e99dc1e} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38634) (comment: 02352_lightweight_delete_and_object_column.sql) (query 2, line 3) (in query: SET allow_experimental_object_type=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:31.645414 [ 18602 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:31.655709 [ 8431 ] {9c3cb4c2-c108-48c4-b32f-025d59567c2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt16OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1383, line 1388) (in query: SELECT toInt16OrNull();) 2025.06.13 15:45:31.668339 [ 5978 ] {2d1b5460-b2e7-4854-b693-ba020460b109} executeQuery: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTRing(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1122, line 1124) (in query: SELECT readWKTRing(-1);) 2025.06.13 15:45:31.694915 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt16OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:31.721742 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be String: In scope SELECT readWKTRing(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:31.825481 [ 8431 ] {af77d682-9aa1-41ef-8bb8-92e8f864c8d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt16OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1384, line 1389) (in query: SELECT toInt16OrZero();) 2025.06.13 15:45:31.838630 [ 5978 ] {aba7d1f4-a6c1-4b7f-955b-1abd7404832d} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 1: In scope SELECT regexpExtract(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1123, line 1125) (in query: SELECT regexpExtract(-1);) 2025.06.13 15:45:31.840529 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt16OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:31.874755 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 1: In scope SELECT regexpExtract(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:31.939026 [ 8431 ] {91b4a308-c370-468d-810e-b5f09b01bea5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256'. Expected 1 argument, got 0 arguments: In scope SELECT toInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1385, line 1390) (in query: SELECT toInt256();) 2025.06.13 15:45:31.976423 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256'. Expected 1 argument, got 0 arguments: In scope SELECT toInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:31.997630 [ 5978 ] {ecb75606-3741-43d8-8775-5a7d748c3e65} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of 1 argument of function regexpQuoteMeta. Must be String.: In scope SELECT regexpQuoteMeta(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1124, line 1126) (in query: SELECT regexpQuoteMeta(-1);) 2025.06.13 15:45:32.006827 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of 1 argument of function regexpQuoteMeta. Must be String.: In scope SELECT regexpQuoteMeta(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:32.071148 [ 8431 ] {c6c57b92-066f-448c-8d5d-d5ae1273f4f0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1386, line 1391) (in query: SELECT toInt256OrDefault();) 2025.06.13 15:45:32.077418 [ 5978 ] {975aed9d-c14f-4a42-861c-e10f024407a5} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionHierarchy (must be UInt32): In scope SELECT regionHierarchy(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1125, line 1127) (in query: SELECT regionHierarchy(-1);) 2025.06.13 15:45:32.081834 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:32.087518 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionHierarchy (must be UInt32): In scope SELECT regionHierarchy(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:32.110000 [ 8101 ] {410a37c3-9f71-46c5-971e-d5e1e6cca3ec} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFiveMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFiveMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 102, line 102) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfFiveMinutes(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:32.122303 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFiveMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFiveMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:32.160180 [ 5978 ] {1587dbd2-bcbb-41f4-9a79-a4c30f058165} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionIn doesn't match: passed 1, should be 2 or 3.: In scope SELECT regionIn(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1126, line 1128) (in query: SELECT regionIn(-1);) 2025.06.13 15:45:32.170044 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionIn doesn't match: passed 1, should be 2 or 3.: In scope SELECT regionIn(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:32.214922 [ 8431 ] {4796d058-f45a-4f08-ae31-7945f982880f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1387, line 1392) (in query: SELECT toInt256OrNull();) 2025.06.13 15:45:32.221375 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:32.339742 [ 8431 ] {bd770920-28bc-4ee0-9ebc-b05461212022} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1388, line 1393) (in query: SELECT toInt256OrZero();) 2025.06.13 15:45:32.436695 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:32.438832 [ 5978 ] {42b41397-3758-40a3-859f-badb346c7435} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionToArea (must be UInt32): In scope SELECT regionToArea(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1127, line 1129) (in query: SELECT regionToArea(-1);) 2025.06.13 15:45:32.443826 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionToArea (must be UInt32): In scope SELECT regionToArea(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:32.531192 [ 5978 ] {3fb7e408-3c97-4d0f-9da9-04bfb725f7e5} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionToCity (must be UInt32): In scope SELECT regionToCity(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1128, line 1130) (in query: SELECT regionToCity(-1);) 2025.06.13 15:45:32.542261 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionToCity (must be UInt32): In scope SELECT regionToCity(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:32.544535 [ 8431 ] {4602521b-b40b-4b0f-bd16-f0304b1271d1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32'. Expected 1 argument, got 0 arguments: In scope SELECT toInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1389, line 1394) (in query: SELECT toInt32();) 2025.06.13 15:45:32.549088 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32'. Expected 1 argument, got 0 arguments: In scope SELECT toInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:32.647285 [ 5978 ] {1845df88-e468-4130-9903-5c03f7734701} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionToContinent (must be UInt32): In scope SELECT regionToContinent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1129, line 1131) (in query: SELECT regionToContinent(-1);) 2025.06.13 15:45:32.648780 [ 8431 ] {c95bb2db-ee52-4e54-81d4-9d780335123e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1390, line 1395) (in query: SELECT toInt32OrDefault();) 2025.06.13 15:45:32.651301 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionToContinent (must be UInt32): In scope SELECT regionToContinent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:32.667722 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:32.770488 [ 8431 ] {7c39200b-ad65-4410-8bbe-284ab5ddd97a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1391, line 1396) (in query: SELECT toInt32OrNull();) 2025.06.13 15:45:32.780909 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:32.814514 [ 5978 ] {a54fbd3f-df3b-430d-866b-2ce8c75178d2} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionToCountry (must be UInt32): In scope SELECT regionToCountry(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1130, line 1132) (in query: SELECT regionToCountry(-1);) 2025.06.13 15:45:32.818951 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionToCountry (must be UInt32): In scope SELECT regionToCountry(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:32.905839 [ 5978 ] {579267f9-6d61-4b43-9cab-33edb1a03821} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionToDistrict (must be UInt32): In scope SELECT regionToDistrict(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1131, line 1133) (in query: SELECT regionToDistrict(-1);) 2025.06.13 15:45:32.910115 [ 8431 ] {50c4bfb3-f6af-4544-a233-c88b4ab856c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1392, line 1397) (in query: SELECT toInt32OrZero();) 2025.06.13 15:45:32.936712 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:32.944355 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionToDistrict (must be UInt32): In scope SELECT regionToDistrict(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:33.024615 [ 5978 ] {da89d70c-822f-4aec-ac45-1b56fdde8ed3} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of the first argument of function regionToName (must be UInt32): In scope SELECT regionToName(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1132, line 1134) (in query: SELECT regionToName(-1);) 2025.06.13 15:45:33.027248 [ 8431 ] {5b571be3-b7e9-47c2-9c3e-2992bb8f965d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64'. Expected 1 argument, got 0 arguments: In scope SELECT toInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1393, line 1398) (in query: SELECT toInt64();) 2025.06.13 15:45:33.039101 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of the first argument of function regionToName (must be UInt32): In scope SELECT regionToName(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:33.052850 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64'. Expected 1 argument, got 0 arguments: In scope SELECT toInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:33.085591 [ 8101 ] {9a7dcb60-7ea8-47f9-88a9-aab17f4b12f1} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfTenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfTenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 107, line 107) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfTenMinutes(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:33.103908 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfTenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfTenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:33.150539 [ 8431 ] {a46c3cb1-45b6-4fc6-b448-5b4a02bf421b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1394, line 1399) (in query: SELECT toInt64OrDefault();) 2025.06.13 15:45:33.163823 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:33.185241 [ 5978 ] {2a680dc3-1b1c-4dcb-945c-bb0b481de54c} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionToPopulation (must be UInt32): In scope SELECT regionToPopulation(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1133, line 1135) (in query: SELECT regionToPopulation(-1);) 2025.06.13 15:45:33.208315 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionToPopulation (must be UInt32): In scope SELECT regionToPopulation(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:33.264367 [ 8431 ] {c4308736-e564-410b-ac42-4cf6e9b14f77} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1395, line 1400) (in query: SELECT toInt64OrNull();) 2025.06.13 15:45:33.290076 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:33.380748 [ 5978 ] {81bdcc72-695b-474e-8f36-92447eed221a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionToTopContinent (must be UInt32): In scope SELECT regionToTopContinent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1134, line 1136) (in query: SELECT regionToTopContinent(-1);) 2025.06.13 15:45:33.392108 [ 8431 ] {da375283-9f4f-4eca-9e2c-6676f714a985} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1396, line 1401) (in query: SELECT toInt64OrZero();) 2025.06.13 15:45:33.399993 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function regionToTopContinent (must be UInt32): In scope SELECT regionToTopContinent(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:33.435170 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:33.544953 [ 8431 ] {7252aa9c-5894-4256-bc40-ca9007e05a16} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8'. Expected 1 argument, got 0 arguments: In scope SELECT toInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1397, line 1402) (in query: SELECT toInt8();) 2025.06.13 15:45:33.554188 [ 5978 ] {d46a183e-cada-4d1e-9495-14b5cebd35eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 1, should be 2: In scope SELECT reinterpret(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1135, line 1137) (in query: SELECT reinterpret(-1);) 2025.06.13 15:45:33.565177 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8'. Expected 1 argument, got 0 arguments: In scope SELECT toInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:33.569243 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 1, should be 2: In scope SELECT reinterpret(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:33.675891 [ 8099 ] {d3cbf420-8104-45f0-aecb-25856f7e7cb1} ~StorageFileSource: Failed to rename file /var/lib/clickhouse/user_files/02732_rename_after_processing_test_3/tmp5.csv: File /var/lib/clickhouse/user_files/02732_rename_after_processing_test_3/tmp.csv already exists 2025.06.13 15:45:33.741903 [ 8431 ] {8bf40579-a789-4b15-92da-b907abfdd2b0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1398, line 1403) (in query: SELECT toInt8OrDefault();) 2025.06.13 15:45:33.763508 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:33.856225 [ 8431 ] {3dbae766-3997-4bce-9a2e-5ee9fd1d533a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt8OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1399, line 1404) (in query: SELECT toInt8OrNull();) 2025.06.13 15:45:33.892812 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt8OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:34.024120 [ 8431 ] {3ded5554-fa46-4edc-9eb7-4e9590a849e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt8OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1400, line 1405) (in query: SELECT toInt8OrZero();) 2025.06.13 15:45:34.035998 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt8OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:34.088750 [ 8101 ] {16824ba6-62cc-4955-9109-680e93b82847} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFifteenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFifteenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 112, line 112) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfFifteenMinutes(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:34.103186 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFifteenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFifteenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:34.145668 [ 8431 ] {047fc3b3-81cd-4c00-83ea-15faf8a2de6e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalDay'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1401, line 1406) (in query: SELECT toIntervalDay();) 2025.06.13 15:45:34.157206 [ 8442 ] {ba277022-67d1-4b97-87ed-3e79e0c71c10} executeQuery: Code: 1. DB::Exception: Resolved identifier 'age_max' in parent scope to expression 'test_9oljsabm.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.20286.altinityantalya (altinity build)) (from [::1]:38668) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String const&, String&&) @ 0x000000002cc5904f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1fcfd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1e4bc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc42299 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2d013 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:45:34.192932 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalDay'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:34.203768 [ 8442 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'age_max' in parent scope to expression 'test_9oljsabm.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String const&, String&&) @ 0x000000002cc5904f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1fcfd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1e4bc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3691: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc055ea 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5615: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9dae 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2670: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000002cc42299 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3179: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2d013 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:45:34.350975 [ 8431 ] {a81d5813-3fc0-4648-ae0f-246d47b393f6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalHour'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1402, line 1407) (in query: SELECT toIntervalHour();) 2025.06.13 15:45:34.360785 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalHour'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:34.413157 [ 4107 ] {aacd900b-5d22-4bde-80e1-ce2d5694f9df} ~StorageFileSource: Failed to rename file /var/lib/clickhouse/user_files/02732_rename_after_processing_test_3/tmp5.csv: File `/var/lib/clickhouse/tmp5.csv` is not inside `/var/lib/clickhouse/user_files/` 2025.06.13 15:45:34.511438 [ 8431 ] {f3e43a6e-cc2d-4add-944f-bc234e6e891d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMicrosecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMicrosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1403, line 1408) (in query: SELECT toIntervalMicrosecond();) 2025.06.13 15:45:34.533892 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMicrosecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMicrosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:34.606909 [ 8431 ] {b58351cb-24c7-45fb-ad7d-aed9390fb623} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMillisecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1404, line 1409) (in query: SELECT toIntervalMillisecond();) 2025.06.13 15:45:34.620609 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMillisecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:34.706097 [ 8431 ] {ad4ea62a-1b4d-44fb-a2b2-3f767e4199cf} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMinute'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1405, line 1410) (in query: SELECT toIntervalMinute();) 2025.06.13 15:45:34.712043 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMinute'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:34.763191 [ 7279 ] {11a368ad-8d3c-48e0-91b1-9657d6775888} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52980) (comment: 01710_projection_query_plan_optimization_misc.sql) (query 2, line 3) (in query: CREATE TABLE t (`x` Int32, `codectest` Int32) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 26900, min_bytes_for_wide_part = 988747212, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 331332213, compact_parts_max_granules_to_buffer = 56, compact_parts_merge_max_bytes_to_prefetch_part = 16974903, merge_max_block_size = 19860, old_parts_lifetime = 232., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 21214916, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 96707, primary_key_compress_block_size = 96356, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:34.780794 [ 7279 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:34.815100 [ 8431 ] {35b9eda3-d87d-4054-9ab9-6f83b52da2ac} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMonth'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1406, line 1411) (in query: SELECT toIntervalMonth();) 2025.06.13 15:45:34.829921 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMonth'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:34.906667 [ 8431 ] {d40397b2-b344-4efc-96ec-e6a2c0e98420} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalNanosecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalNanosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1407, line 1412) (in query: SELECT toIntervalNanosecond();) 2025.06.13 15:45:34.927262 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalNanosecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalNanosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:35.006752 [ 5112 ] {9a35c949-3424-44df-9d3d-e6360b48752e} executeQuery: Code: 36. DB::Exception: Invalid renaming rule: Allowed placeholders only %a, %f, %e, %t, and %%. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53000) (comment: 02732_rename_after_processing.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM file('02732_rename_after_processing_test_3/tmp5.csv')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Common/FileRenamer.cpp:76: DB::FileRenamer::validateRenamingRule(String const&, bool) @ 0x00000000304016b7 6. ./build_docker/./src/Common/FileRenamer.cpp:29: DB::FileRenamer::FileRenamer(String const&) @ 0x00000000304013e1 7. ./build_docker/./src/Storages/StorageFile.cpp:1061: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000303d589f 8. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000303d6177 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageFile* std::construct_at[abi:ne190107](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284ca20b 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284ca043 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284c9e74 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284c7039 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 15. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:45:35.007476 [ 8431 ] {2e5cc0cb-467d-4595-8a15-b5ba1517c964} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalQuarter'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1408, line 1413) (in query: SELECT toIntervalQuarter();) 2025.06.13 15:45:35.007870 [ 8101 ] {f7a2ed3f-6d01-4eab-9b6e-18bdaffaaf77} executeQuery: Code: 43. DB::Exception: A timezone argument of function toStartOfInterval with interval type Year is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalYear(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 117, line 117) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfInterval(N, INTERVAL 1 year, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:35.014905 [ 2868 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5503 similar messages) 2025.06.13 15:45:35.019573 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalQuarter'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:35.057268 [ 9644 ] {438c1259-b95f-46b8-8780-2e8f1fee0a88} executeQuery: Code: 36. DB::Exception: Number of aliases does not match number of projection columns. Expected 2, got 1. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 03280_aliases_for_selects_and_views.sql) (query 4, line 19) (in query: SELECT a FROM ( SELECT number, number*2 FROM numbers(2) ) AS x (a);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x00000000239773cf 5. ./build_docker/./src/Analyzer/QueryNode.cpp:60: DB::QueryNode::resolveProjectionColumns(std::vector>) @ 0x000000002caa8b08 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5787: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb68d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:45:35.099411 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: A timezone argument of function toStartOfInterval with interval type Year is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalYear(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:35.111347 [ 9644 ] {} TCPHandler: Code: 36. DB::Exception: Number of aliases does not match number of projection columns. Expected 2, got 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x00000000239773cf 5. ./build_docker/./src/Analyzer/QueryNode.cpp:60: DB::QueryNode::resolveProjectionColumns(std::vector>) @ 0x000000002caa8b08 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5787: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb68d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:45:35.132546 [ 8431 ] {c88a7667-3dd3-4acb-b66d-0b28b79c6b9e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalSecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1409, line 1414) (in query: SELECT toIntervalSecond();) 2025.06.13 15:45:35.180191 [ 5112 ] {} TCPHandler: Code: 36. DB::Exception: Invalid renaming rule: Allowed placeholders only %a, %f, %e, %t, and %%. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Common/FileRenamer.cpp:76: DB::FileRenamer::validateRenamingRule(String const&, bool) @ 0x00000000304016b7 6. ./build_docker/./src/Common/FileRenamer.cpp:29: DB::FileRenamer::FileRenamer(String const&) @ 0x00000000304013e1 7. ./build_docker/./src/Storages/StorageFile.cpp:1061: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000303d589f 8. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000303d6177 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageFile* std::construct_at[abi:ne190107](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284ca20b 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284ca043 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284c9e74 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284c7039 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 15. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:45:35.189810 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalSecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:35.254806 [ 9644 ] {6d842c34-37cf-4772-8f28-9f499d8193a7} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `c` in scope SELECT c FROM (SELECT number, number * 2 FROM numbers(2)) AS x (a, b). Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 03280_aliases_for_selects_and_views.sql) (query 5, line 25) (in query: SELECT c FROM ( SELECT number, number*2 FROM numbers(2) ) as x (a, b);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:45:35.260916 [ 9644 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `c` in scope SELECT c FROM (SELECT number, number * 2 FROM numbers(2)) AS x (a, b). Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:45:35.262931 [ 8431 ] {1bbfb451-5f53-4ee2-84ac-8976f9d91375} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalWeek'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1410, line 1415) (in query: SELECT toIntervalWeek();) 2025.06.13 15:45:35.267010 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalWeek'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:35.414784 [ 8431 ] {3b8ddd1c-f422-4282-a085-42fdbbac2a34} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalYear'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1411, line 1416) (in query: SELECT toIntervalYear();) 2025.06.13 15:45:35.421404 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalYear'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:35.483578 [ 8431 ] {cb655ca9-0749-4b5e-9f01-436523e524e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 0, should be 1: In scope SELECT toJSONString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1412, line 1417) (in query: SELECT toJSONString();) 2025.06.13 15:45:35.491390 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 0, should be 1: In scope SELECT toJSONString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:35.601049 [ 8431 ] {dae1d3f6-b458-4984-9218-fdeba46a6506} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toLastDayOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1413, line 1418) (in query: SELECT toLastDayOfMonth();) 2025.06.13 15:45:35.635501 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toLastDayOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:35.750417 [ 8431 ] {cdb79109-36da-4dfc-874d-f0ad381e942b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toLastDayOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1414, line 1419) (in query: SELECT toLastDayOfWeek();) 2025.06.13 15:45:35.775937 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toLastDayOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:35.860352 [ 5163 ] {94c15d0e-6c5b-405f-8796-49c7b2d4d1ff} executeQuery: Code: 36. DB::Exception: Invalid renaming rule: Odd number of consecutive percentage signs. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53070) (comment: 02732_rename_after_processing.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM file('02732_rename_after_processing_test_3/tmp5.csv')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Common/FileRenamer.cpp:89: DB::FileRenamer::validateRenamingRule(String const&, bool) @ 0x000000003040173c 6. ./build_docker/./src/Common/FileRenamer.cpp:29: DB::FileRenamer::FileRenamer(String const&) @ 0x00000000304013e1 7. ./build_docker/./src/Storages/StorageFile.cpp:1061: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000303d589f 8. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000303d6177 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageFile* std::construct_at[abi:ne190107](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284ca20b 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284ca043 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284c9e74 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284c7039 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 15. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:45:35.874846 [ 8431 ] {25c891f0-4c36-4345-abc5-d127447f5126} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 0, should be 1: In scope SELECT toLowCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1415, line 1420) (in query: SELECT toLowCardinality();) 2025.06.13 15:45:35.878380 [ 5163 ] {} TCPHandler: Code: 36. DB::Exception: Invalid renaming rule: Odd number of consecutive percentage signs. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Common/FileRenamer.cpp:89: DB::FileRenamer::validateRenamingRule(String const&, bool) @ 0x000000003040173c 6. ./build_docker/./src/Common/FileRenamer.cpp:29: DB::FileRenamer::FileRenamer(String const&) @ 0x00000000304013e1 7. ./build_docker/./src/Storages/StorageFile.cpp:1061: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000303d589f 8. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000303d6177 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageFile* std::construct_at[abi:ne190107](DB::StorageFile*, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284ca20b 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], 0>(std::allocator, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284ca043 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000284c9e74 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x00000000284c7039 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284cc40b 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 15. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:45:35.880833 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 0, should be 1: In scope SELECT toLowCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:35.992983 [ 8431 ] {5f5d740c-7b4b-4aff-adaf-6d6250fe4e29} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1416, line 1421) (in query: SELECT toMillisecond();) 2025.06.13 15:45:36.009159 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:36.012239 [ 9644 ] {0da95ef8-c766-44df-bb73-ad42f1a3b71d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `c` in scope SELECT c FROM test_view_03280. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 03280_aliases_for_selects_and_views.sql) (query 10, line 39) (in query: SELECT c FROM test_view_03280;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:45:36.025569 [ 9644 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `c` in scope SELECT c FROM test_view_03280. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:45:36.037468 [ 8101 ] {7b97fd64-44b9-40ee-825a-29730e120f22} executeQuery: Code: 43. DB::Exception: A timezone argument of function toStartOfInterval with interval type Month is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMonth(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 122, line 122) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfInterval(N, INTERVAL 1 month, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:36.047528 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: A timezone argument of function toStartOfInterval with interval type Month is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMonth(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:36.138044 [ 8431 ] {90a3a28f-5ad6-4173-a735-49422c285a82} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT toMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1417, line 1422) (in query: SELECT toMinute();) 2025.06.13 15:45:36.161384 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT toMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:36.313125 [ 8431 ] {d71f9247-6e53-40a4-b241-d9cb34ee8db2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 0, should be 1: In scope SELECT toModifiedJulianDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1418, line 1423) (in query: SELECT toModifiedJulianDay();) 2025.06.13 15:45:36.336952 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 0, should be 1: In scope SELECT toModifiedJulianDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:36.385525 [ 9644 ] {c8ef4858-b2d9-4376-9ebb-041b71b21b6d} executeQuery: Code: 36. DB::Exception: Number of aliases does not match number of expressions in SELECT list. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 03280_aliases_for_selects_and_views.sql) (query 12, line 43) (in query: CREATE VIEW test_view_1_03280 (a) AS SELECT 1, 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:940: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc6437c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:45:36.394095 [ 9644 ] {} TCPHandler: Code: 36. DB::Exception: Number of aliases does not match number of expressions in SELECT list. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:940: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc6437c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:45:36.470430 [ 3821 ] {cde7ca82-6677-42ac-b031-4ebb63fdc310} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42180) (comment: 00700_decimal_aggregates.sql) (query 81, line 108) (in query: SELECT covarPop(a, a), covarPop(b, b), covarPop(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000245398ef 5. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000264baf2a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:45:36.558600 [ 3821 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000245398ef 5. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000264baf2a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:45:36.568375 [ 8431 ] {4a61c8f4-65de-42cd-b0ab-d5fba173e86d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 0, should be 1: In scope SELECT toModifiedJulianDayOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1419, line 1424) (in query: SELECT toModifiedJulianDayOrNull();) 2025.06.13 15:45:36.584103 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 0, should be 1: In scope SELECT toModifiedJulianDayOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:36.644934 [ 8431 ] {0a281d4a-52fb-46d2-9cc8-e8d92e738083} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonday doesn't match: passed 0, should be 1 or 2: In scope SELECT toMonday(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1420, line 1425) (in query: SELECT toMonday();) 2025.06.13 15:45:36.652533 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonday doesn't match: passed 0, should be 1 or 2: In scope SELECT toMonday(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:36.735173 [ 6193 ] {e21678eb-24a3-4602-9472-ef02c9a8de00} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53116) (comment: 01490_nullable_string_to_enum.sql) (query 3, line 4) (in query: CREATE TABLE t_enum(x Enum8('hello' = 1, 'world' = 2)) ENGINE = TinyLog;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:36.761377 [ 6193 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:36.816023 [ 3821 ] {dcd6605e-96e6-4d40-8d6c-635c03bbb8aa} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42180) (comment: 00700_decimal_aggregates.sql) (query 82, line 109) (in query: SELECT covarSamp(a, a), covarSamp(b, b), covarSamp(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000245398ef 5. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000264baa8a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:45:36.844954 [ 8431 ] {efb1ffbe-06b1-4244-a383-a828b825aeb3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1421, line 1426) (in query: SELECT toMonth();) 2025.06.13 15:45:36.845983 [ 3821 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000245398ef 5. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000264baa8a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:45:36.885706 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:37.047349 [ 8431 ] {3e58ef16-0452-4162-8d46-5791d9f158ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonthNumSinceEpoch doesn't match: passed 0, should be 1 or 2: In scope SELECT toMonthNumSinceEpoch(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1422, line 1427) (in query: SELECT toMonthNumSinceEpoch();) 2025.06.13 15:45:37.069348 [ 3821 ] {c75d001f-ad7c-48ae-8e0a-0973a8f5176f} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42180) (comment: 00700_decimal_aggregates.sql) (query 83, line 110) (in query: SELECT corr(a, a), corr(b, b), corr(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000245398ef 5. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000266d1e6a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:45:37.073913 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonthNumSinceEpoch doesn't match: passed 0, should be 1 or 2: In scope SELECT toMonthNumSinceEpoch(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:37.087463 [ 3821 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000245398ef 5. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000266d1e6a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:45:37.167996 [ 8431 ] {0d253751-c6db-4a7d-b384-80e67e1ac695} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 0, should be 1: In scope SELECT toNullable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1423, line 1428) (in query: SELECT toNullable();) 2025.06.13 15:45:37.194147 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 0, should be 1: In scope SELECT toNullable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:37.382677 [ 8431 ] {ce80b322-8c92-4ff6-9d14-1f8acd23e1e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT toQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1424, line 1429) (in query: SELECT toQuarter();) 2025.06.13 15:45:37.408109 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT toQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:37.453079 [ 9644 ] {414c913a-b07c-4b5b-9b1d-76be88f72eb8} executeQuery: Code: 36. DB::Exception: Number of aliases does not match number of projection columns. Expected 2, got 1. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 03280_aliases_for_selects_and_views.sql) (query 17, line 65) (in query: WITH t (a) AS ( SELECT 1, 2 ) SELECT b FROM t;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x00000000239773cf 5. ./build_docker/./src/Analyzer/QueryNode.cpp:60: DB::QueryNode::resolveProjectionColumns(std::vector>) @ 0x000000002caa8b08 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5787: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb68d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:45:37.483150 [ 9644 ] {} TCPHandler: Code: 36. DB::Exception: Number of aliases does not match number of projection columns. Expected 2, got 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x00000000239773cf 5. ./build_docker/./src/Analyzer/QueryNode.cpp:60: DB::QueryNode::resolveProjectionColumns(std::vector>) @ 0x000000002caa8b08 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5787: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb68d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:45:37.515767 [ 8431 ] {2432e3e0-3d7b-490c-a5bc-843ee93c7b38} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeDayNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeDayNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1425, line 1430) (in query: SELECT toRelativeDayNum();) 2025.06.13 15:45:37.528518 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeDayNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeDayNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:37.578239 [ 5005 ] {27ce9269-7fda-4b6a-b72b-9ce12016edce} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53222) (comment: 02025_subcolumns_compact_parts.sql) (query 2, line 3) (in query: CREATE TABLE t_comp_subcolumns (`id` UInt32, `n` Nullable(String), `arr` Array(Array(UInt32))) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 3037, min_bytes_for_wide_part = 210942646, 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 = 490765688, compact_parts_max_granules_to_buffer = 136, compact_parts_merge_max_bytes_to_prefetch_part = 7146935, merge_max_block_size = 13184, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 4878072863, 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 = 8943090, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 49, 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 = 38225, primary_key_compress_block_size = 44735, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:37.579588 [ 5978 ] {51e3b863-1bfd-484a-8031-193f5a0c77f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 1, should be 2: In scope SELECT repeat(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1155, line 1157) (in query: SELECT repeat(-1);) 2025.06.13 15:45:37.596878 [ 5005 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:37.608429 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 1, should be 2: In scope SELECT repeat(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:37.624398 [ 9644 ] {4ff8afb6-274d-45d3-ad2b-37d755ffed80} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `c` in scope WITH t (a, b) AS (SELECT 1, 2) SELECT c FROM t. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52968) (comment: 03280_aliases_for_selects_and_views.sql) (query 18, line 71) (in query: WITH t (a, b) AS ( SELECT 1, 2 ) SELECT c FROM t;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:45:37.635190 [ 9644 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `c` in scope WITH t (a, b) AS (SELECT 1, 2) SELECT c FROM t. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:45:37.651850 [ 8431 ] {c01f106e-3144-4a04-919b-de82fb9e1739} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeHourNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeHourNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1426, line 1431) (in query: SELECT toRelativeHourNum();) 2025.06.13 15:45:37.673638 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeHourNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeHourNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:37.786792 [ 5978 ] {cc5001ec-8a6a-4512-b6bd-5ed091009ca0} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 1, should be 3: In scope SELECT replace(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1156, line 1158) (in query: SELECT replace(-1);) 2025.06.13 15:45:37.796818 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 1, should be 3: In scope SELECT replace(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:37.929064 [ 5978 ] {d2b6622e-6cad-4fd7-9ea9-277e3fa7543b} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 1, should be 3: In scope SELECT replaceAll(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1157, line 1159) (in query: SELECT replaceAll(-1);) 2025.06.13 15:45:37.938431 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 1, should be 3: In scope SELECT replaceAll(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:37.955970 [ 8431 ] {5ce39bea-dfa6-4a13-b884-a6c9c6b5f626} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeMinuteNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeMinuteNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1427, line 1432) (in query: SELECT toRelativeMinuteNum();) 2025.06.13 15:45:37.963090 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeMinuteNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeMinuteNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:38.043397 [ 5978 ] {1bde9148-5782-44a5-8ccd-ad4047f26efb} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 1, should be 3: In scope SELECT replaceOne(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1158, line 1160) (in query: SELECT replaceOne(-1);) 2025.06.13 15:45:38.089858 [ 8431 ] {323187a9-b718-4dc4-bbc9-46bd158084ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeMonthNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeMonthNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1428, line 1433) (in query: SELECT toRelativeMonthNum();) 2025.06.13 15:45:38.106990 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeMonthNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeMonthNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:38.133069 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 1, should be 3: In scope SELECT replaceOne(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:38.198841 [ 8431 ] {604ea76e-9e06-408a-82c2-f4e7047db95e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeQuarterNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeQuarterNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1429, line 1434) (in query: SELECT toRelativeQuarterNum();) 2025.06.13 15:45:38.212784 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeQuarterNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeQuarterNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:38.213550 [ 5978 ] {acb26db4-0b16-497b-a901-1f90669870d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 1, should be 3: In scope SELECT replaceRegexpAll(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1159, line 1161) (in query: SELECT replaceRegexpAll(-1);) 2025.06.13 15:45:38.227883 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 1, should be 3: In scope SELECT replaceRegexpAll(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:38.242256 [ 8101 ] {bd747e2e-cf92-4ce1-a3e5-ec7091470184} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMinute(15), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 132, line 132) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfInterval(N, INTERVAL 15 minute, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:38.260386 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMinute(15), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:38.315682 [ 8431 ] {144894d6-a566-4759-bd41-aa36f361d9f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeSecondNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeSecondNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1430, line 1435) (in query: SELECT toRelativeSecondNum();) 2025.06.13 15:45:38.335042 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeSecondNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeSecondNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:38.398846 [ 5978 ] {de049b1c-5ba9-4d84-aded-b1b6658af2f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 1, should be 3: In scope SELECT replaceRegexpOne(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1160, line 1162) (in query: SELECT replaceRegexpOne(-1);) 2025.06.13 15:45:38.408918 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 1, should be 3: In scope SELECT replaceRegexpOne(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:38.432806 [ 8431 ] {6c96fcee-6486-4183-93b1-5f31b15805df} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeWeekNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeWeekNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1431, line 1436) (in query: SELECT toRelativeWeekNum();) 2025.06.13 15:45:38.444667 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeWeekNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeWeekNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:38.508199 [ 5978 ] {1d62fb81-1385-45c6-959b-011012d01785} executeQuery: Code: 35. DB::Exception: Function replicate expect at least two arguments, got 1: In scope SELECT replicate(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1161, line 1163) (in query: SELECT replicate(-1);) 2025.06.13 15:45:38.516650 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: Function replicate expect at least two arguments, got 1: In scope SELECT replicate(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:45:38.595743 [ 8431 ] {e9d0799e-a8b8-4e96-ab41-9704b3b36885} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeYearNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeYearNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1432, line 1437) (in query: SELECT toRelativeYearNum();) 2025.06.13 15:45:38.625411 [ 5978 ] {ee04d53f-8191-4d65-92f1-e3225808ce78} executeQuery: Code: 42. DB::Exception: Not enough event arguments for aggregate function retention. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1162, line 1164) (in query: SELECT retention(-1);) 2025.06.13 15:45:38.629372 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeYearNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeYearNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:38.634197 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Not enough event arguments for aggregate function retention. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:38.751468 [ 5978 ] {efaea2f8-28b2-4339-9873-0d5d0cc820bc} executeQuery: Code: 44. DB::Exception: Illegal column Int8 of argument of function reverse: In scope SELECT reverse(-1). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1163, line 1165) (in query: SELECT reverse(-1);) 2025.06.13 15:45:38.779991 [ 5978 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column Int8 of argument of function reverse: In scope SELECT reverse(-1). (ILLEGAL_COLUMN) 2025.06.13 15:45:38.793095 [ 8431 ] {1c8abd6d-8b77-4bcf-be15-9b6b8cbeb165} executeQuery: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1433, line 1438) (in query: SELECT toSecond();) 2025.06.13 15:45:38.821263 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:38.878692 [ 5978 ] {f360cd3c-f890-403f-8f0a-964aabe06c6d} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function reverseUTF8: In scope SELECT reverseUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1164, line 1166) (in query: SELECT reverseUTF8(-1);) 2025.06.13 15:45:38.888590 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function reverseUTF8: In scope SELECT reverseUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:38.925039 [ 8431 ] {37b25068-d740-4a03-994a-95f4ef4fb932} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfDay doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1434, line 1439) (in query: SELECT toStartOfDay();) 2025.06.13 15:45:38.957158 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfDay doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:39.102603 [ 5978 ] {1d16c59f-5a07-4e6e-83f8-302c53572172} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 1, should be 0: In scope SELECT revision(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1165, line 1167) (in query: SELECT revision(-1);) 2025.06.13 15:45:39.108761 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 1, should be 0: In scope SELECT revision(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:39.163743 [ 8431 ] {ea184ed4-76f7-4c19-8dae-4e6f78d8445c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFifteenMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFifteenMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1435, line 1440) (in query: SELECT toStartOfFifteenMinutes();) 2025.06.13 15:45:39.169599 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFifteenMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFifteenMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:39.213124 [ 8101 ] {3c5097d3-0421-4da3-a458-726bd28bd3f3} executeQuery: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'year' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('year', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 137, line 137) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), date_trunc('year', N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:39.215487 [ 18510 ] {d98d5d59-2c06-41e4-bd41-6f6655ca3ec0} executeQuery: Code: 60. DB::Exception: Table test_11.ddl_test_for_opentelemetry_non_exist does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53362) (comment: 02423_ddl_for_opentelemetry.sh) (query 1, line 1) (in query: DROP TABLE test_11.ddl_test_for_opentelemetry_non_exist ON CLUSTER test_11), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:45:39.218007 [ 5978 ] {e27a48aa-b6c2-4e35-8e1e-f5ae4534696b} executeQuery: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 1, should be 2: In scope SELECT right(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1166, line 1168) (in query: SELECT right(-1);) 2025.06.13 15:45:39.226608 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'year' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('year', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:39.229258 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 1, should be 2: In scope SELECT right(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:39.244673 [ 18510 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.ddl_test_for_opentelemetry_non_exist does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:45:39.312796 [ 8431 ] {797fb46d-c2d0-4f00-9b7d-ffd7219e5994} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFiveMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1436, line 1441) (in query: SELECT toStartOfFiveMinute();) 2025.06.13 15:45:39.336391 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFiveMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:39.366736 [ 5978 ] {2b687d11-3115-4325-969d-377690b2b120} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 1, should be 2 or 3: In scope SELECT rightPad(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1167, line 1169) (in query: SELECT rightPad(-1);) 2025.06.13 15:45:39.378322 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 1, should be 2 or 3: In scope SELECT rightPad(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:39.571493 [ 8431 ] {41f6c942-9900-4b5a-9ca7-8e16030b0a28} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFiveMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1437, line 1442) (in query: SELECT toStartOfFiveMinutes();) 2025.06.13 15:45:39.571636 [ 5978 ] {3bb15b53-9106-4548-a9e5-1f06048f3006} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPadUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT rightPadUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1168, line 1170) (in query: SELECT rightPadUTF8(-1);) 2025.06.13 15:45:39.583920 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFiveMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:39.585735 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPadUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT rightPadUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:39.671607 [ 8431 ] {5f45c33c-d8be-48cf-8a95-e403b1cdf636} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfHour doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1438, line 1443) (in query: SELECT toStartOfHour();) 2025.06.13 15:45:39.675968 [ 5978 ] {5e02be28-1424-4ba6-8f58-22088c69ce0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 1, should be 2: In scope SELECT rightUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1169, line 1171) (in query: SELECT rightUTF8(-1);) 2025.06.13 15:45:39.692224 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfHour doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:39.707964 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 1, should be 2: In scope SELECT rightUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:39.874119 [ 9636 ] {be484979-7b9d-4d38-ba65-407d0e55275e} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: In scope SELECT mapFromArrays([toLowCardinality(toNullable(1)), toLowCardinality(CAST(NULL, 'Nullable(Int32)'))], [3, 4]) GROUP BY 1. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53292) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 6, line 16) (in query: SELECT mapFromArrays( [toLowCardinality(toNullable(1)), toLowCardinality(cast(NULL as Nullable(Int32)))], [3, 4] ) GROUP BY 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcd8584 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:45:39.904327 [ 8431 ] {5b965f88-637a-4ae7-9712-87401143972e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfISOYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfISOYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1439, line 1444) (in query: SELECT toStartOfISOYear();) 2025.06.13 15:45:39.909589 [ 9636 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: In scope SELECT mapFromArrays([toLowCardinality(toNullable(1)), toLowCardinality(CAST(NULL, 'Nullable(Int32)'))], [3, 4]) GROUP BY 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcd8584 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:45:39.919868 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfISOYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfISOYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:40.027930 [ 8431 ] {20c8cf0b-9bb7-43ac-9783-f90127bf6731} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 0, must be 2, 3 or 4: In scope SELECT toStartOfInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1440, line 1445) (in query: SELECT toStartOfInterval();) 2025.06.13 15:45:40.037197 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 0, must be 2, 3 or 4: In scope SELECT toStartOfInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:40.080013 [ 9636 ] {f4424b30-d947-40a2-a38d-9c6167a47d7f} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: In scope SELECT mapFromArrays([toLowCardinality(toNullable('x')), toLowCardinality(CAST(NULL, 'Nullable(String)'))], [3, 4]) GROUP BY 1. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53292) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 7, line 21) (in query: SELECT mapFromArrays( [toLowCardinality(toNullable('x')), toLowCardinality(cast(NULL as Nullable(String)))], [3, 4] ) GROUP BY 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcd8584 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:45:40.089640 [ 9636 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: In scope SELECT mapFromArrays([toLowCardinality(toNullable('x')), toLowCardinality(CAST(NULL, 'Nullable(String)'))], [3, 4]) GROUP BY 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001dcd8584 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:45:40.122799 [ 8431 ] {effd97f1-5691-44cc-9092-b5bd54e907c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMicrosecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMicrosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1441, line 1446) (in query: SELECT toStartOfMicrosecond();) 2025.06.13 15:45:40.128151 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMicrosecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMicrosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:40.201634 [ 8431 ] {4d16cd67-f2ac-465b-a241-6f855f423d26} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1442, line 1447) (in query: SELECT toStartOfMillisecond();) 2025.06.13 15:45:40.232258 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:40.273739 [ 8101 ] {7178c2cf-7b04-4506-9f90-548e63828893} executeQuery: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'month' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('month', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 142, line 142) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), date_trunc('month', N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:40.282084 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'month' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('month', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:40.397981 [ 5978 ] {1c587d40-09a0-4199-a2d0-2ee3ae60f89b} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 1, should be 2: In scope SELECT roundDown(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1173, line 1175) (in query: SELECT roundDown(-1);) 2025.06.13 15:45:40.412029 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 1, should be 2: In scope SELECT roundDown(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:40.464775 [ 8431 ] {1ff42469-c7db-441d-882f-82aca9d9912f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1443, line 1448) (in query: SELECT toStartOfMinute();) 2025.06.13 15:45:40.470941 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:40.541925 [ 8431 ] {7a639086-22ba-4211-8894-7eaaa3ff658c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1444, line 1449) (in query: SELECT toStartOfMonth();) 2025.06.13 15:45:40.551942 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:40.660885 [ 8431 ] {d6d9ae17-2b07-435b-917a-3b98b12ccf3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfNanosecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfNanosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1445, line 1450) (in query: SELECT toStartOfNanosecond();) 2025.06.13 15:45:40.680896 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfNanosecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfNanosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:40.792669 [ 8431 ] {dee0d966-5a8c-40b0-af2f-55b2a28aab0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1446, line 1451) (in query: SELECT toStartOfQuarter();) 2025.06.13 15:45:40.803946 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:40.880521 [ 5978 ] {f589a233-64d6-4e04-b1cd-698ceb9d874c} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 1, should be 0: In scope SELECT rowNumberInAllBlocks(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1176, line 1178) (in query: SELECT rowNumberInAllBlocks(-1);) 2025.06.13 15:45:40.889900 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 1, should be 0: In scope SELECT rowNumberInAllBlocks(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:40.890286 [ 8431 ] {cf368501-d020-48da-b10c-27c745e0bffd} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1447, line 1452) (in query: SELECT toStartOfSecond();) 2025.06.13 15:45:40.900739 [ 9636 ] {875e46b5-7535-4f76-8f60-92feaf92700b} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53292) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 12, line 33) (in query: CREATE TABLE 03399_lc_nullable_int_simple( k Array(LowCardinality(Nullable(Int32))), v Array(Int32) ) engine = Memory AS SELECT [1, 2], [3, 4];), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:40.909574 [ 8431 ] {} 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) 2025.06.13 15:45:40.924200 [ 9636 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:40.995513 [ 8431 ] {5f3f1836-c93b-487b-9da4-452ae0fad5cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfTenMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfTenMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1448, line 1453) (in query: SELECT toStartOfTenMinutes();) 2025.06.13 15:45:41.000150 [ 5978 ] {33afa8df-c28e-4948-a215-ad970456ec3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 1, should be 0: In scope SELECT rowNumberInBlock(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1177, line 1179) (in query: SELECT rowNumberInBlock(-1);) 2025.06.13 15:45:41.017986 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfTenMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfTenMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:41.020450 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 1, should be 0: In scope SELECT rowNumberInBlock(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:41.119253 [ 8431 ] {9ba67c2f-90f2-4d5c-900d-8af469e1d6aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toStartOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1449, line 1454) (in query: SELECT toStartOfWeek();) 2025.06.13 15:45:41.128490 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toStartOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:41.148514 [ 5978 ] {bbd70003-d2dc-4077-9ed0-fce9574ad151} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1178, line 1180) (in query: SELECT row_number(-1);) 2025.06.13 15:45:41.152423 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:45:41.215309 [ 5978 ] {3ffb94cc-adc8-41e2-803e-4eaead6a1ef2} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 1, should be 2 or 3: In scope SELECT rpad(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1179, line 1181) (in query: SELECT rpad(-1);) 2025.06.13 15:45:41.239290 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 1, should be 2 or 3: In scope SELECT rpad(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:41.252637 [ 8431 ] {d20b4f78-d548-402d-a364-c58aa858f21b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1450, line 1455) (in query: SELECT toStartOfYear();) 2025.06.13 15:45:41.270895 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:41.352266 [ 5978 ] {fc83347e-7e82-4c36-a719-a42426f027be} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimRight'. Expected: String, got: Int8: In scope SELECT trimRight(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1180, line 1182) (in query: SELECT rtrim(-1);) 2025.06.13 15:45:41.368995 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimRight'. Expected: String, got: Int8: In scope SELECT trimRight(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:41.392600 [ 8431 ] {78436235-ee7b-4fb0-aee4-4f46acefadd3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toString'. Expected 1 argument, got 0 arguments: In scope SELECT toString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1451, line 1456) (in query: SELECT toString();) 2025.06.13 15:45:41.495740 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toString'. Expected 1 argument, got 0 arguments: In scope SELECT toString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:41.570043 [ 5978 ] {4c7eec39-9ca3-4067-ae56-8f6ac9ff74b6} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1181, line 1183) (in query: SELECT runningAccumulate(-1);) 2025.06.13 15:45:41.653511 [ 5978 ] {} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:45:41.675484 [ 8431 ] {5587e2b5-bbaa-4c68-b239-2274550be45a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 0, should be 1: In scope SELECT toStringCutToZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1452, line 1457) (in query: SELECT toStringCutToZero();) 2025.06.13 15:45:41.687682 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 0, should be 1: In scope SELECT toStringCutToZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:41.765804 [ 5978 ] {adc4584d-04d0-4ab8-a311-0a8f5ddda3fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 1, should be 2: In scope SELECT runningConcurrency(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1182, line 1184) (in query: SELECT runningConcurrency(-1);) 2025.06.13 15:45:41.771127 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 1, should be 2: In scope SELECT runningConcurrency(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:41.853049 [ 8431 ] {bc84e078-af46-44e3-a13e-87235654e134} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTime doesn't match: passed 0, should be 1 or 2: In scope SELECT toTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1453, line 1458) (in query: SELECT toTime();) 2025.06.13 15:45:41.861827 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTime doesn't match: passed 0, should be 1 or 2: In scope SELECT toTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:42.022051 [ 8431 ] {048a0812-d2a5-4171-a4e6-672dd776a19b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 0, should be 2: In scope SELECT toTimeZone(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1454, line 1459) (in query: SELECT toTimeZone();) 2025.06.13 15:45:42.032524 [ 6234 ] {f0da8ce0-bcea-4861-b166-6ea36f0dfc86} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53100) (comment: 03150_dynamic_type_mv_insert.sql) (query 21, line 40) (in query: DROP TABLE null_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:45:42.035618 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 0, should be 2: In scope SELECT toTimeZone(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:42.036619 [ 5978 ] {ca3e6e4e-43c0-4515-86cb-f56434e7d070} 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.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1183, line 1185) (in query: SELECT runningDifference(-1);) 2025.06.13 15:45:42.052152 [ 6234 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:45:42.088386 [ 5978 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:45:42.243483 [ 8431 ] {6369bd74-1e38-40d7-acc3-eeadd9863fed} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 0, should be 2: In scope SELECT toTimezone(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1455, line 1460) (in query: SELECT toTimezone();) 2025.06.13 15:45:42.255894 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 0, should be 2: In scope SELECT toTimezone(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:42.294962 [ 5978 ] {7f0dfa72-3c5d-464a-9d71-01a49925a7c7} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1184, line 1186) (in query: SELECT runningDifferenceStartingWithFirstValue(-1);) 2025.06.13 15:45:42.310717 [ 18510 ] {1f7b81ae-c1c7-48f9-9ba4-c6304cd2a44a} executeQuery: Code: 36. DB::Exception: GROUPING function argument number % 3 is not in GROUP BY keys. In query SELECT number, grouping(number, number % 2, number % 3) = 6 FROM remote('127.0.0.{2,3}', numbers(10)) GROUP BY number, number % 2 ORDER BY number ASC. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53482) (comment: 02293_grouping_function_group_by.sql) (query 2, line 3) (in query: SELECT number, grouping(number, number % 2, number % 3) = 6 FROM remote('127.0.0.{2,3}', numbers(10)) GROUP BY number, number % 2 ORDER BY number;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:182: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a745 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:45:42.325777 [ 5978 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:45:42.331478 [ 18510 ] {} TCPHandler: Code: 36. DB::Exception: GROUPING function argument number % 3 is not in GROUP BY keys. In query SELECT number, grouping(number, number % 2, number % 3) = 6 FROM remote('127.0.0.{2,3}', numbers(10)) GROUP BY number, number % 2 ORDER BY number ASC. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:182: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a745 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:45:42.350115 [ 8101 ] {e03e5927-61ee-49e0-b847-f91a3f71950b} executeQuery: Code: 43. DB::Exception: Illegal type Date of argument for function dateTrunc: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('minute', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 152, line 152) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), date_trunc('minute', N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:42.362010 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of argument for function dateTrunc: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('minute', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:42.424085 [ 5978 ] {a376686b-f97f-452c-bc6a-2c5028e08261} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 1, should be 3: In scope SELECT s2CapContains(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1185, line 1187) (in query: SELECT s2CapContains(-1);) 2025.06.13 15:45:42.424698 [ 8431 ] {c5998e67-d594-4038-b4b3-814718b47f41} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 0, should be 1: In scope SELECT toTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1456, line 1461) (in query: SELECT toTypeName();) 2025.06.13 15:45:42.429724 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 0, should be 1: In scope SELECT toTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:42.430588 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 1, should be 3: In scope SELECT s2CapContains(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:42.531919 [ 8431 ] {ef30e12b-7d6e-4c62-b5f2-c54a31c86226} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1457, line 1462) (in query: SELECT toUInt128();) 2025.06.13 15:45:42.537001 [ 5978 ] {19635087-1b7b-4dab-b4e9-316db8600ca1} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 1, should be 4: In scope SELECT s2CapUnion(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1186, line 1188) (in query: SELECT s2CapUnion(-1);) 2025.06.13 15:45:42.552245 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 1, should be 4: In scope SELECT s2CapUnion(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:42.552685 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:42.710478 [ 5110 ] {78a50d3d-4aae-4ceb-a568-f2470e6a6a3b} executeQuery: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53490) (comment: 00927_disable_hyperscan.sql) (query 5, line 10) (in query: SELECT multiMatchAny(arrayJoin(['hello', 'world', 'hellllllllo', 'wororld', 'abc']), ['hel+o', 'w(or)*ld']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0f95fd 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:45:42.728784 [ 5978 ] {32c74f7f-2373-4fba-8a5e-cefc57803d79} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 1, should be 2: In scope SELECT s2CellsIntersect(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1187, line 1189) (in query: SELECT s2CellsIntersect(-1);) 2025.06.13 15:45:42.737712 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 1, should be 2: In scope SELECT s2CellsIntersect(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:42.744185 [ 8431 ] {bfe0eb79-b66d-4b50-96fe-c740e06701fa} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1458, line 1463) (in query: SELECT toUInt128OrDefault();) 2025.06.13 15:45:42.749341 [ 5110 ] {} TCPHandler: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0f95fd 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:45:42.793429 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:42.893049 [ 5978 ] {8dbc99df-80ef-4624-8de3-0a33a6af9727} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function s2GetNeighbors. Must be UInt64: In scope SELECT s2GetNeighbors(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1188, line 1190) (in query: SELECT s2GetNeighbors(-1);) 2025.06.13 15:45:42.911864 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function s2GetNeighbors. Must be UInt64: In scope SELECT s2GetNeighbors(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:42.914789 [ 8431 ] {c8619454-c198-4f2b-882f-2a0e1a38e787} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1459, line 1464) (in query: SELECT toUInt128OrNull();) 2025.06.13 15:45:42.937324 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:43.036747 [ 5978 ] {abefdcc3-8339-4017-980e-b102cbd949d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 1, should be 3: In scope SELECT s2RectAdd(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1189, line 1191) (in query: SELECT s2RectAdd(-1);) 2025.06.13 15:45:43.113794 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 1, should be 3: In scope SELECT s2RectAdd(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:43.119427 [ 8431 ] {a0890f95-cf27-4d04-931f-112800d4bb24} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1460, line 1465) (in query: SELECT toUInt128OrZero();) 2025.06.13 15:45:43.135959 [ 5110 ] {47f7f0ea-0faa-4c0d-af30-5b21ba796617} executeQuery: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53490) (comment: 00927_disable_hyperscan.sql) (query 6, line 11) (in query: SELECT multiMatchAny(arrayJoin(['hello', 'world', 'hellllllllo', 'wororld', 'abc']), materialize(['hel+o', 'w(or)*ld']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0f99c4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:45:43.137740 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:43.144515 [ 5110 ] {} TCPHandler: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0f99c4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:45:43.219129 [ 8101 ] {28036e00-ecbe-4f81-aa6d-17fef7cec564} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTime(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 157, line 157) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toTime(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:43.235985 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTime(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:43.238778 [ 5978 ] {94af7aaf-83f4-4a14-832b-c0fbd190ab1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 1, should be 3: In scope SELECT s2RectContains(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1190, line 1192) (in query: SELECT s2RectContains(-1);) 2025.06.13 15:45:43.249201 [ 8431 ] {d6ae87a8-f512-4c8c-a38e-832b1e9e8b46} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1461, line 1466) (in query: SELECT toUInt16();) 2025.06.13 15:45:43.251975 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 1, should be 3: In scope SELECT s2RectContains(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:43.266493 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:43.354632 [ 5978 ] {7dc07b84-4f09-4c7b-8baa-72552eedd9ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 1, should be 4: In scope SELECT s2RectIntersection(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1191, line 1193) (in query: SELECT s2RectIntersection(-1);) 2025.06.13 15:45:43.355101 [ 8431 ] {fdacf6d7-4e7c-4c09-920c-05f28c09697e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1462, line 1467) (in query: SELECT toUInt16OrDefault();) 2025.06.13 15:45:43.409244 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 1, should be 4: In scope SELECT s2RectIntersection(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:43.412940 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:43.486484 [ 5110 ] {cb719896-a8a7-4b16-961e-7d7fbc529f46} executeQuery: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53490) (comment: 00927_disable_hyperscan.sql) (query 7, line 13) (in query: SELECT multiMatchAllIndices(arrayJoin(['hello', 'world', 'hellllllllo', 'wororld', 'abc']), ['hel+o', 'w(or)*ld']);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0163bd 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:45:43.492560 [ 5110 ] {} TCPHandler: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f0163bd 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:45:43.501019 [ 8431 ] {8de18efe-cbc0-4cae-bbd7-603bec89d04b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt16OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1463, line 1468) (in query: SELECT toUInt16OrNull();) 2025.06.13 15:45:43.519822 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt16OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:43.540130 [ 5978 ] {f46fef41-1a6f-4fe1-8d31-28b615e17b2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 1, should be 4: In scope SELECT s2RectUnion(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1192, line 1194) (in query: SELECT s2RectUnion(-1);) 2025.06.13 15:45:43.559026 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 1, should be 4: In scope SELECT s2RectUnion(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:43.636808 [ 8431 ] {ffc30194-9d74-498f-be87-1ed4a0a4c0b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt16OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1464, line 1469) (in query: SELECT toUInt16OrZero();) 2025.06.13 15:45:43.643812 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt16OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:43.651011 [ 5978 ] {9379a1f4-48d4-45c8-9cac-35c2adfaea1e} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function s2ToGeo. Must be UInt64: In scope SELECT s2ToGeo(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1193, line 1195) (in query: SELECT s2ToGeo(-1);) 2025.06.13 15:45:43.659291 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function s2ToGeo. Must be UInt64: In scope SELECT s2ToGeo(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:43.726073 [ 8431 ] {c600e6c8-6350-4038-9148-031155bde162} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1465, line 1470) (in query: SELECT toUInt256();) 2025.06.13 15:45:43.732646 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:43.747368 [ 5978 ] {a40d1ebc-d492-4efd-861d-952863279b4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 1, should be 2: In scope SELECT scalarProduct(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1194, line 1196) (in query: SELECT scalarProduct(-1);) 2025.06.13 15:45:43.755149 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 1, should be 2: In scope SELECT scalarProduct(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:43.776067 [ 5110 ] {5ec83487-52f9-487f-bba6-6e6cf4296bb6} executeQuery: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53490) (comment: 00927_disable_hyperscan.sql) (query 8, line 14) (in query: SELECT multiMatchAllIndices(arrayJoin(['hello', 'world', 'hellllllllo', 'wororld', 'abc']), materialize(['hel+o', 'w(or)*ld']));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f016752 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:45:43.824380 [ 5110 ] {} TCPHandler: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f016752 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:45:43.889457 [ 8431 ] {8354bd1b-015d-48ca-a3d3-ad03a176e724} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1466, line 1471) (in query: SELECT toUInt256OrDefault();) 2025.06.13 15:45:43.894643 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:43.968678 [ 5978 ] {c52f66f8-b1d8-4a84-852b-20eddb80f0d1} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1195, line 1197) (in query: SELECT sequenceCount(-1);) 2025.06.13 15:45:43.999541 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:44.051172 [ 8431 ] {b5f730e3-75b6-49d4-9799-a05f55cd933c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1467, line 1472) (in query: SELECT toUInt256OrNull();) 2025.06.13 15:45:44.069307 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:44.102936 [ 5978 ] {da8467d9-a359-409c-9baf-6b86c225621b} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1196, line 1198) (in query: SELECT sequenceMatch(-1);) 2025.06.13 15:45:44.119062 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:44.142350 [ 8431 ] {8fa0a222-23ac-42de-be36-40c5e254c052} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1468, line 1473) (in query: SELECT toUInt256OrZero();) 2025.06.13 15:45:44.159649 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:44.221307 [ 5978 ] {c77d7571-3ed4-42bb-971e-24ad6380963a} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceMatchEvents requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1197, line 1199) (in query: SELECT sequenceMatchEvents(-1);) 2025.06.13 15:45:44.239216 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceMatchEvents requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:44.262692 [ 8431 ] {3ccc840b-277d-4db4-b6c0-9959014e992a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1469, line 1474) (in query: SELECT toUInt32();) 2025.06.13 15:45:44.266825 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:44.320405 [ 5978 ] {b871d9a3-304f-4931-98b9-c9f79458fd4f} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1198, line 1200) (in query: SELECT sequenceNextNode(-1);) 2025.06.13 15:45:44.330529 [ 5978 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.06.13 15:45:44.357401 [ 8431 ] {a5568c93-1328-4f1d-b556-46b4060aed30} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1470, line 1475) (in query: SELECT toUInt32OrDefault();) 2025.06.13 15:45:44.371488 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:44.436714 [ 5978 ] {d63809f5-c954-4623-92ab-e6566b9711e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 1, should be 2: In scope SELECT seriesDecomposeSTL(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1199, line 1201) (in query: SELECT seriesDecomposeSTL(-1);) 2025.06.13 15:45:44.466656 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 1, should be 2: In scope SELECT seriesDecomposeSTL(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:44.476711 [ 8431 ] {0f5b2718-0cf3-420b-bea5-a2b1281e4a6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1471, line 1476) (in query: SELECT toUInt32OrNull();) 2025.06.13 15:45:44.501215 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:44.523998 [ 18510 ] {027a4673-71da-4ea0-866c-483d0f51ce99} executeQuery: Code: 36. DB::Exception: Argument __table1.number of GROUPING function is not a part of GROUP BY clause [number % 2, __table1.number]. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53482) (comment: 02293_grouping_function_group_by.sql) (query 5, line 34) (in query: SELECT number, grouping(number, number % 2) AS gr FROM remote('127.0.0.{2,3}', numbers(10)) GROUP BY number, number % 2 WITH ROLLUP ORDER BY number, gr SETTINGS force_grouping_standard_compatibility=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, std::ranges::transform_view[abi:llvm18_nua], std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, std::ranges::transform_view[abi:llvm18_nua], std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, char>>::type>, String&&, fmt::v11::join_view, std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, std::ranges::transform_view[abi:llvm18_nua], std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, char>&&) @ 0x000000002ccaf615 5. ./build_docker/./src/Analyzer/Passes/GroupingFunctionsResolvePass.cpp:98: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccae8e8 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:205: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccae4b5 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:205: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccae4b5 8. ./build_docker/./src/Analyzer/Passes/GroupingFunctionsResolvePass.cpp:261: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccabb91 9. ./build_docker/./src/Analyzer/Passes/GroupingFunctionsResolvePass.cpp:289: DB::GroupingFunctionsResolvePass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cca9c2d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:45:44.582676 [ 18510 ] {} TCPHandler: Code: 36. DB::Exception: Argument __table1.number of GROUPING function is not a part of GROUP BY clause [number % 2, __table1.number]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, std::ranges::transform_view[abi:llvm18_nua], std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, std::ranges::transform_view[abi:llvm18_nua], std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, char>>::type>, String&&, fmt::v11::join_view, std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, std::ranges::transform_view[abi:llvm18_nua], std::allocator>>>, DB::(anonymous namespace)::GroupingFunctionResolveVisitor::enterImpl(std::shared_ptr const&)::'lambda'(auto const&)>::__iterator, char>&&) @ 0x000000002ccaf615 5. ./build_docker/./src/Analyzer/Passes/GroupingFunctionsResolvePass.cpp:98: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccae8e8 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:205: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccae4b5 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:205: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccae4b5 8. ./build_docker/./src/Analyzer/Passes/GroupingFunctionsResolvePass.cpp:261: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x000000002ccabb91 9. ./build_docker/./src/Analyzer/Passes/GroupingFunctionsResolvePass.cpp:289: DB::GroupingFunctionsResolvePass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cca9c2d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:45:44.610415 [ 8431 ] {d07504af-4bf3-40a6-b8c8-8df5b7a16745} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1472, line 1477) (in query: SELECT toUInt32OrZero();) 2025.06.13 15:45:44.619181 [ 5978 ] {bf6efd10-b76b-49e6-8477-109074b7b65a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time_series' to function 'seriesOutliersDetectTukey'. Expected: Array, got: Int8: In scope SELECT seriesOutliersDetectTukey(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1200, line 1202) (in query: SELECT seriesOutliersDetectTukey(-1);) 2025.06.13 15:45:44.627648 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:44.640901 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time_series' to function 'seriesOutliersDetectTukey'. Expected: Array, got: Int8: In scope SELECT seriesOutliersDetectTukey(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:44.771371 [ 8431 ] {74a2e75f-bbc1-4022-83ce-68a2bf798853} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1473, line 1478) (in query: SELECT toUInt64();) 2025.06.13 15:45:44.777496 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:44.958073 [ 5978 ] {67ec255a-9f83-4f31-8940-7ad83323d3a3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time_series' to function 'seriesPeriodDetectFFT'. Expected: Array, got: Int8: In scope SELECT seriesPeriodDetectFFT(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1201, line 1203) (in query: SELECT seriesPeriodDetectFFT(-1);) 2025.06.13 15:45:44.966826 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time_series' to function 'seriesPeriodDetectFFT'. Expected: Array, got: Int8: In scope SELECT seriesPeriodDetectFFT(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:45.024408 [ 8431 ] {3b628aab-185b-4eb9-a266-8dd73d116a0d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1474, line 1479) (in query: SELECT toUInt64OrDefault();) 2025.06.13 15:45:45.030987 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:45.125071 [ 5978 ] {c81e6954-06e0-4fc5-99a3-d48c29e7cdaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 1, should be 0: In scope SELECT serverTimeZone(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1202, line 1204) (in query: SELECT serverTimeZone(-1);) 2025.06.13 15:45:45.146197 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 1, should be 0: In scope SELECT serverTimeZone(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:45.158098 [ 8431 ] {f7c23550-b39b-4481-9152-df70f41d9dd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1475, line 1480) (in query: SELECT toUInt64OrNull();) 2025.06.13 15:45:45.165433 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:45.249885 [ 5978 ] {da846ee6-6341-4fb9-bad5-8317cba43ff3} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 1, should be 0: In scope SELECT serverTimezone(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1203, line 1205) (in query: SELECT serverTimezone(-1);) 2025.06.13 15:45:45.259184 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 1, should be 0: In scope SELECT serverTimezone(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:45.267682 [ 8431 ] {125030e5-6a30-4afe-849b-bd7b9f13c614} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1476, line 1481) (in query: SELECT toUInt64OrZero();) 2025.06.13 15:45:45.290205 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:45.340092 [ 5978 ] {b2dfa8d5-295d-4798-a777-e7bb09cad30b} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 1, should be 0: In scope SELECT serverUUID(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1204, line 1206) (in query: SELECT serverUUID(-1);) 2025.06.13 15:45:45.374533 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 1, should be 0: In scope SELECT serverUUID(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:45.389024 [ 8431 ] {58247682-46d0-4de3-bba0-445c933b16b1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1477, line 1482) (in query: SELECT toUInt8();) 2025.06.13 15:45:45.397078 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:45.469308 [ 5978 ] {3509a0fc-7b07-459c-9d16-b4af610d8864} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 1, should be 0: In scope SELECT shardCount(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1205, line 1207) (in query: SELECT shardCount(-1);) 2025.06.13 15:45:45.477593 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 1, should be 0: In scope SELECT shardCount(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:45.490315 [ 8431 ] {29e91128-411e-4a37-a901-0eb6a32ffcf2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1478, line 1483) (in query: SELECT toUInt8OrDefault();) 2025.06.13 15:45:45.535406 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:45.583038 [ 5978 ] {ea91123a-236b-4263-a4f9-961bbe9a72b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 1, should be 0: In scope SELECT shardNum(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1206, line 1208) (in query: SELECT shardNum(-1);) 2025.06.13 15:45:45.598016 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 1, should be 0: In scope SELECT shardNum(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:45.657205 [ 8431 ] {469bce4e-767f-4af3-8ee9-587a499d147d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt8OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1479, line 1484) (in query: SELECT toUInt8OrNull();) 2025.06.13 15:45:45.700379 [ 5978 ] {47eae0a6-eb61-4be5-b215-d00a73915c01} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 1, should be 0: In scope SELECT showCertificate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1207, line 1209) (in query: SELECT showCertificate(-1);) 2025.06.13 15:45:45.697733 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt8OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:45.818966 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 1, should be 0: In scope SELECT showCertificate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:45.914400 [ 8431 ] {5cca43ff-48d3-4ca9-8450-3208d0488481} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt8OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1480, line 1485) (in query: SELECT toUInt8OrZero();) 2025.06.13 15:45:45.926377 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt8OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:46.060706 [ 8431 ] {ca5cf844-3377-4d26-8881-3d07f1277f21} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT toUTCTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1481, line 1486) (in query: SELECT toUTCTimestamp();) 2025.06.13 15:45:46.080527 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT toUTCTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:46.151987 [ 3821 ] {9f664057-10ef-4db8-8f58-547711c4ca48} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53920) (comment: 01232_untuple.sql) (query 8, line 10) (in query: CREATE TABLE kv (`key` int, `v1` int, `v2` int, `v3` int, `v4` int, `v5` int) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 33425, min_bytes_for_wide_part = 362493874, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 122, min_bytes_for_full_part_storage = 298438780, compact_parts_max_bytes_to_buffer = 257035765, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 31044598, merge_max_block_size = 19633, old_parts_lifetime = 76., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 872949, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 12387725, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 52, 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 = 16847, primary_key_compress_block_size = 18454, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:46.179701 [ 3821 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:46.204623 [ 8431 ] {ee086ed2-7c52-411b-b239-145fe2604b22} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUID'. Expected 1 argument, got 0 arguments: In scope SELECT toUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1482, line 1487) (in query: SELECT toUUID();) 2025.06.13 15:45:46.225359 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUID'. Expected 1 argument, got 0 arguments: In scope SELECT toUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:46.337142 [ 8431 ] {b3222db6-1a4e-41a4-b9e6-cf26d6434c72} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUUIDOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1483, line 1488) (in query: SELECT toUUIDOrDefault();) 2025.06.13 15:45:46.341748 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUUIDOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:46.354158 [ 5978 ] {3ef85211-60c7-4949-a8b6-f9e05b7d5fdf} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractBool(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1210, line 1212) (in query: SELECT simpleJSONExtractBool(-1);) 2025.06.13 15:45:46.358391 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractBool(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:46.463584 [ 8431 ] {17ce8359-3fa5-41f5-8a0e-116f6321e767} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUUIDOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1484, line 1489) (in query: SELECT toUUIDOrNull();) 2025.06.13 15:45:46.465905 [ 5978 ] {2acdcb13-a9c0-4e87-a0f1-ce8d086f2f97} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractFloat(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1211, line 1213) (in query: SELECT simpleJSONExtractFloat(-1);) 2025.06.13 15:45:46.479436 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUUIDOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:46.484633 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractFloat(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:46.645548 [ 5978 ] {fc9d7849-c11b-4e4f-941e-2373cf5dcfbc} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractInt(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1212, line 1214) (in query: SELECT simpleJSONExtractInt(-1);) 2025.06.13 15:45:46.665483 [ 8431 ] {214195db-4a29-4e24-863b-b4221bff53b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUUIDOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1485, line 1490) (in query: SELECT toUUIDOrZero();) 2025.06.13 15:45:46.763654 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractInt(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:46.763982 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUUIDOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:46.818682 [ 8431 ] {da23ac27-be1a-4194-86f3-fde02501fe4f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUnixTimestamp'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUnixTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1486, line 1491) (in query: SELECT toUnixTimestamp();) 2025.06.13 15:45:46.829886 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUnixTimestamp'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUnixTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:46.834668 [ 5978 ] {071cde9c-da4b-45c4-923d-c80519c15b50} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractRaw(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1213, line 1215) (in query: SELECT simpleJSONExtractRaw(-1);) 2025.06.13 15:45:46.853994 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractRaw(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:46.880220 [ 18602 ] {c98ef6e4-5800-45f6-948f-6fa824d9b501} executeQuery: Code: 10. DB::Exception: Not found column toUInt128(__table2.id): in block __table2.id UUID UUID(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53936) (comment: 03393_join_bug_77848.sql) (query 8, line 11) (in query: -- TODO(@vdimir): NOT_FOUND_COLUMN_IN_BLOCK is a bug, should be fixed -- This tests ensures that query does not crash at least SELECT 1 FROM BadTable i LEFT JOIN BadJoin c ON i.id_uint = toUInt128(c.id) WHERE equals(i.id_uint, 12);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:977: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb18eb5 6. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 7. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 8. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&&, bool&) @ 0x000000002dd40500 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:154: DB::QueryPlanOptimizations::addNewFilterStepOrThrow(DB::QueryPlan::Node*, std::list>&, DB::ActionsDAG, bool, unsigned long, bool) @ 0x00000000322b84ee 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:398: DB::QueryPlanOptimizations::tryPushDownOverJoinStep(DB::QueryPlan::Node*, std::list>&, std::unique_ptr>&) @ 0x00000000322b5f96 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:581: DB::QueryPlanOptimizations::tryPushDownFilter(DB::QueryPlan::Node*, std::list>&, DB::QueryPlanOptimizations::Optimization::ExtraSettings const&) @ 0x00000000322b2d26 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:95: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003227f64b 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a74 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:45:46.897709 [ 18602 ] {} TCPHandler: Code: 10. DB::Exception: Not found column toUInt128(__table2.id): in block __table2.id UUID UUID(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:977: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb18eb5 6. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 7. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 8. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&&, bool&) @ 0x000000002dd40500 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:154: DB::QueryPlanOptimizations::addNewFilterStepOrThrow(DB::QueryPlan::Node*, std::list>&, DB::ActionsDAG, bool, unsigned long, bool) @ 0x00000000322b84ee 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:398: DB::QueryPlanOptimizations::tryPushDownOverJoinStep(DB::QueryPlan::Node*, std::list>&, std::unique_ptr>&) @ 0x00000000322b5f96 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:581: DB::QueryPlanOptimizations::tryPushDownFilter(DB::QueryPlan::Node*, std::list>&, DB::QueryPlanOptimizations::Optimization::ExtraSettings const&) @ 0x00000000322b2d26 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:95: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003227f64b 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a74 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:45:46.923173 [ 8431 ] {be189d15-0f81-45c3-b14b-0873e18090f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1487, line 1492) (in query: SELECT toUnixTimestamp64Micro();) 2025.06.13 15:45:46.952434 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:46.965442 [ 5978 ] {71a2b287-9747-46b6-8450-445dcc8076e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractString(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1214, line 1216) (in query: SELECT simpleJSONExtractString(-1);) 2025.06.13 15:45:46.978448 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractString(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:47.008646 [ 18602 ] {781e50a5-1ca5-4db0-98e9-cce3df7e42fd} executeQuery: Code: 10. DB::Exception: Not found column toUInt128(__table2.id): in block __table2.id UUID UUID(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53936) (comment: 03393_join_bug_77848.sql) (query 9, line 16) (in query: SELECT equals(i.id_uint, 12) FROM BadTable i LEFT JOIN BadJoin c ON i.id_uint = toUInt128(c.id) WHERE equals(i.id_uint, 12);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:977: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb18eb5 6. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 7. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 8. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&&, bool&) @ 0x000000002dd40500 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:154: DB::QueryPlanOptimizations::addNewFilterStepOrThrow(DB::QueryPlan::Node*, std::list>&, DB::ActionsDAG, bool, unsigned long, bool) @ 0x00000000322b84ee 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:398: DB::QueryPlanOptimizations::tryPushDownOverJoinStep(DB::QueryPlan::Node*, std::list>&, std::unique_ptr>&) @ 0x00000000322b5f96 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:581: DB::QueryPlanOptimizations::tryPushDownFilter(DB::QueryPlan::Node*, std::list>&, DB::QueryPlanOptimizations::Optimization::ExtraSettings const&) @ 0x00000000322b2d26 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:95: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003227f64b 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a74 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:45:47.015405 [ 18602 ] {} TCPHandler: Code: 10. DB::Exception: Not found column toUInt128(__table2.id): in block __table2.id UUID UUID(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:977: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb18eb5 6. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 7. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 8. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&&, bool&) @ 0x000000002dd40500 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:154: DB::QueryPlanOptimizations::addNewFilterStepOrThrow(DB::QueryPlan::Node*, std::list>&, DB::ActionsDAG, bool, unsigned long, bool) @ 0x00000000322b84ee 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:398: DB::QueryPlanOptimizations::tryPushDownOverJoinStep(DB::QueryPlan::Node*, std::list>&, std::unique_ptr>&) @ 0x00000000322b5f96 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:581: DB::QueryPlanOptimizations::tryPushDownFilter(DB::QueryPlan::Node*, std::list>&, DB::QueryPlanOptimizations::Optimization::ExtraSettings const&) @ 0x00000000322b2d26 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:95: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003227f64b 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a74 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:45:47.052218 [ 8431 ] {bebce92f-3580-4273-b1ce-f49fbe1223d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1488, line 1493) (in query: SELECT toUnixTimestamp64Milli();) 2025.06.13 15:45:47.086048 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:47.126747 [ 5978 ] {b3ccc73b-e9c2-4bd6-ab07-24d44510a05a} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractUInt(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1215, line 1217) (in query: SELECT simpleJSONExtractUInt(-1);) 2025.06.13 15:45:47.135924 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 1, should be 2: In scope SELECT simpleJSONExtractUInt(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:47.187924 [ 8431 ] {933ef23d-6424-46dc-8bd1-3cc14fe31026} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1489, line 1494) (in query: SELECT toUnixTimestamp64Nano();) 2025.06.13 15:45:47.198489 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:47.245161 [ 5978 ] {14452a9c-0fde-4650-9ed1-892d57b84f2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 1, should be 2: In scope SELECT simpleJSONHas(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1216, line 1218) (in query: SELECT simpleJSONHas(-1);) 2025.06.13 15:45:47.252563 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 1, should be 2: In scope SELECT simpleJSONHas(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:47.353841 [ 8431 ] {d327e73c-a9e2-4dcc-b4df-f2783e1d9a6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Second(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1490, line 1495) (in query: SELECT toUnixTimestamp64Second();) 2025.06.13 15:45:47.356306 [ 18511 ] {415e0075-0a5c-4d1a-a28f-5774f8964b35} 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.20286.altinityantalya (altinity build)) (from [::1]:54032) (comment: 03128_argMin_combinator_projection.sql) (query 3, line 4) (in query: CREATE TABLE combinator_argMin_table_r1 (`id` Int32, `value` Int32, `agg_time` DateTime, PROJECTION first_items (SELECT id, minArgMin(agg_time, value), maxArgMax(agg_time, value) GROUP BY id)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_03128/combinator_argMin_table', 'r1') ORDER BY id SETTINGS index_granularity = 65250, min_bytes_for_wide_part = 817602040, ratio_of_defaults_for_sparse_serialization = 0.6491813659667969, 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 = 324283221, compact_parts_max_granules_to_buffer = 102, compact_parts_merge_max_bytes_to_prefetch_part = 9018518, merge_max_block_size = 12408, old_parts_lifetime = 196., prefer_fetch_merged_part_size_threshold = 9885992641, vertical_merge_algorithm_min_rows_to_activate = 781763, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 1692712145, index_granularity_bytes = 566977, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 82003, primary_key_compress_block_size = 13901, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:47.379068 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Second(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:47.384276 [ 5978 ] {f4c131de-6228-49a0-a8f6-d60eb80c3e6e} executeQuery: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1217, line 1219) (in query: SELECT simpleLinearRegression(-1);) 2025.06.13 15:45:47.393041 [ 18511 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:47.396079 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:47.434795 [ 8099 ] {512e115e-827f-42fe-8db1-a964d10bc1a8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59060) (comment: 03393_join_bug_77848.sql) (in query: DROP DATABASE IF EXISTS test_p9rj973q SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:45:47.439657 [ 8099 ] {512e115e-827f-42fe-8db1-a964d10bc1a8} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:45:47.461250 [ 8431 ] {fa09232a-7b15-4de3-807b-8af6685a3a92} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 0, should be 1: In scope SELECT toValidUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1491, line 1496) (in query: SELECT toValidUTF8();) 2025.06.13 15:45:47.475854 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 0, should be 1: In scope SELECT toValidUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:47.557887 [ 8431 ] {9949cf4a-1b24-4be4-bd43-a7328160df63} executeQuery: Code: 42. DB::Exception: Number of arguments for function toWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1492, line 1497) (in query: SELECT toWeek();) 2025.06.13 15:45:47.574432 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:47.653761 [ 8431 ] {5a15a02b-f03f-4317-9927-a826d909be39} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMM doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1493, line 1498) (in query: SELECT toYYYYMM();) 2025.06.13 15:45:47.676035 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMM doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:47.761720 [ 8431 ] {52e5fb61-fc57-44ec-aa29-111e588dc3fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDD doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMMDD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1494, line 1499) (in query: SELECT toYYYYMMDD();) 2025.06.13 15:45:47.794253 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDD doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMMDD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:47.937431 [ 8431 ] {009bc2a1-85db-4938-996d-649da67b2ef7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDDhhmmss doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMMDDhhmmss(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1495, line 1500) (in query: SELECT toYYYYMMDDhhmmss();) 2025.06.13 15:45:47.942943 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDDhhmmss doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMMDDhhmmss(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:48.014140 [ 8431 ] {93b259ee-59be-4f86-baa2-2150a26e2c0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1496, line 1501) (in query: SELECT toYear();) 2025.06.13 15:45:48.044145 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:48.149857 [ 5978 ] {c1fe56fb-b952-4ca7-8d4c-b1179804f06a} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1222, line 1224) (in query: SELECT sipHash128Keyed(-1);) 2025.06.13 15:45:48.170285 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed(-1). (BAD_ARGUMENTS) 2025.06.13 15:45:48.241067 [ 8431 ] {cf16b78c-31cf-4e41-90d6-8c4aeba10134} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYearNumSinceEpoch doesn't match: passed 0, should be 1 or 2: In scope SELECT toYearNumSinceEpoch(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1497, line 1502) (in query: SELECT toYearNumSinceEpoch();) 2025.06.13 15:45:48.260123 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYearNumSinceEpoch doesn't match: passed 0, should be 1 or 2: In scope SELECT toYearNumSinceEpoch(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:48.351330 [ 8431 ] {ee8b4d3a-7271-4f94-9603-d7adddbb77bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYearWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toYearWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1498, line 1503) (in query: SELECT toYearWeek();) 2025.06.13 15:45:48.378963 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYearWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toYearWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:48.469971 [ 18380 ] {b6b4008f-73cb-4ee2-8fa6-fc62744281d4} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54112) (comment: 01470_test_insert_select_asterisk.sql) (query 3, line 4) (in query: CREATE TABLE insert_select_dst (i int, middle_a int, middle_b int, j int) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:48.480628 [ 18380 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:48.546089 [ 5978 ] {56989fbf-e874-4eb4-bbbf-3b4be3afa204} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1224, line 1226) (in query: SELECT sipHash128ReferenceKeyed(-1);) 2025.06.13 15:45:48.571029 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed(-1). (BAD_ARGUMENTS) 2025.06.13 15:45:48.574026 [ 8431 ] {1280ec1f-206f-4d39-84b2-370a82a94df1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT to_utc_timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1499, line 1504) (in query: SELECT to_utc_timestamp();) 2025.06.13 15:45:48.609428 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT to_utc_timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:48.809331 [ 8431 ] {556490d1-1004-4e19-9600-e3882e30d008} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 0, should be 1: In scope SELECT tokens(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1501, line 1506) (in query: SELECT tokens();) 2025.06.13 15:45:48.812801 [ 5978 ] {9c2e9fab-1087-408c-9f88-12885d4ed72c} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1226, line 1228) (in query: SELECT sipHash64Keyed(-1);) 2025.06.13 15:45:48.815549 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 0, should be 1: In scope SELECT tokens(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:48.824543 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed(-1). (BAD_ARGUMENTS) 2025.06.13 15:45:48.896877 [ 8431 ] {a02fac74-6f3e-47fc-b52d-15fe6af98caa} executeQuery: Code: 42. DB::Exception: Aggregate function topK requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1502, line 1507) (in query: SELECT topK();) 2025.06.13 15:45:48.916950 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function topK requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:49.070074 [ 8431 ] {d43b0726-55ca-4d80-8cd9-d7bba16c9a29} executeQuery: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1503, line 1508) (in query: SELECT topKWeighted();) 2025.06.13 15:45:49.104371 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:49.294991 [ 18380 ] {ddd043b9-8c39-42da-bd26-a1b00ad2d9ab} executeQuery: Code: 38. DB::Exception: Cannot parse date here: abcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 1, line 1) (in query: select * from format(CSV, 'd Date, s String', 'abcdefgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:49.309251 [ 8431 ] {07bde539-92fe-49ee-ab7b-74bb6d8269f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 0, should be 1: In scope SELECT topLevelDomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1504, line 1509) (in query: SELECT topLevelDomain();) 2025.06.13 15:45:49.320377 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: abcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:49.353540 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 0, should be 1: In scope SELECT topLevelDomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:49.423416 [ 8431 ] {40ef32f1-4ef2-40a6-9f19-1baf533a5a80} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 0, should be 1: In scope SELECT topLevelDomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1505, line 1510) (in query: SELECT topLevelDomainRFC();) 2025.06.13 15:45:49.436811 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 0, should be 1: In scope SELECT topLevelDomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:49.443322 [ 18380 ] {5aa3b753-1802-4ace-84f2-ba19b9dc797e} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2bcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 2, line 2) (in query: select * from format(CSV, 'd Date, s String', '2bcdefgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:49.462006 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2bcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:49.478500 [ 5978 ] {58277561-9670-49b4-b7c9-5748dce6915b} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function sleep, expected UInt* or Float*: In scope SELECT sleep(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1229, line 1231) (in query: SELECT sleep(-1);) 2025.06.13 15:45:49.485730 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function sleep, expected UInt* or Float*: In scope SELECT sleep(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:49.541440 [ 5978 ] {a8372284-a86e-4526-b9e6-e0b6fd978498} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function sleepEachRow, expected UInt* or Float*: In scope SELECT sleepEachRow(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1230, line 1232) (in query: SELECT sleepEachRow(-1);) 2025.06.13 15:45:49.548057 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function sleepEachRow, expected UInt* or Float*: In scope SELECT sleepEachRow(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:49.570008 [ 18380 ] {99c588c0-6562-414d-87e1-caaf2aee3df1} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 20cdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 3, line 3) (in query: select * from format(CSV, 'd Date, s String', '20cdefgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:49.590691 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 20cdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:49.645679 [ 5978 ] {61459031-25f0-447b-8869-aebf01fbead5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: Int8: In scope SELECT snowflakeIDToDateTime(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1231, line 1233) (in query: SELECT snowflakeIDToDateTime(-1);) 2025.06.13 15:45:49.659713 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: Int8: In scope SELECT snowflakeIDToDateTime(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:49.955918 [ 18380 ] {8312b44c-3821-47a4-8cce-1c80e179c852} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 202defgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 4, line 4) (in query: select * from format(CSV, 'd Date, s String', '202defgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:49.956961 [ 5978 ] {a6356231-383a-4e96-8a2a-36ff62d6296e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: Int8: In scope SELECT snowflakeIDToDateTime64(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1232, line 1234) (in query: SELECT snowflakeIDToDateTime64(-1);) 2025.06.13 15:45:49.963913 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 202defgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:49.971784 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: Int8: In scope SELECT snowflakeIDToDateTime64(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:50.102923 [ 18380 ] {a56e5876-941f-4cde-8d6e-2df66e30fc05} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020efgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 5, line 5) (in query: select * from format(CSV, 'd Date, s String', '2020efgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:50.107519 [ 5978 ] {972fd6c2-9a2d-4c73-83c1-64c5f5d3b466} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime'. Expected: Int64, got: Int8: In scope SELECT snowflakeToDateTime(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1233, line 1235) (in query: SELECT snowflakeToDateTime(-1);) 2025.06.13 15:45:50.110206 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020efgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:50.126812 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime'. Expected: Int64, got: Int8: In scope SELECT snowflakeToDateTime(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:50.234554 [ 8431 ] {c653a57b-5c80-4bcf-91ce-bedf50db88d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 0, should be 3 or 4: In scope SELECT transform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1509, line 1514) (in query: SELECT transform();) 2025.06.13 15:45:50.240758 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 0, should be 3 or 4: In scope SELECT transform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:50.257052 [ 18380 ] {3673f359-de83-4b2a-9ed7-5ca290e2fd8f} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 20200fgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 6, line 6) (in query: select * from format(CSV, 'd Date, s String', '20200fgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:50.269926 [ 5978 ] {2b1ef411-9305-4f1d-aae4-d92cf4f6917b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime64'. Expected: Int64, got: Int8: In scope SELECT snowflakeToDateTime64(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1234, line 1236) (in query: SELECT snowflakeToDateTime64(-1);) 2025.06.13 15:45:50.271613 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 20200fgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:50.295123 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime64'. Expected: Int64, got: Int8: In scope SELECT snowflakeToDateTime64(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:50.364031 [ 8431 ] {973b8cc8-7413-40f6-849e-60304fbf5024} executeQuery: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 0, should be 3: In scope SELECT translate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1510, line 1515) (in query: SELECT translate();) 2025.06.13 15:45:50.371771 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 0, should be 3: In scope SELECT translate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:50.390906 [ 18380 ] {b1f893ca-9e79-4307-95db-cacdfc4edd5d} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 202001gh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 7, line 7) (in query: select * from format(CSV, 'd Date, s String', '202001gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:50.404207 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 202001gh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:50.410075 [ 5978 ] {ed42fe05-3415-426f-bc23-b4ecff896c74} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function soundex: In scope SELECT soundex(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1235, line 1237) (in query: SELECT soundex(-1);) 2025.06.13 15:45:50.416811 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function soundex: In scope SELECT soundex(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:50.510848 [ 18380 ] {523417a0-fe42-4e94-ad97-e8cb97c0731e} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020010h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 8, line 8) (in query: select * from format(CSV, 'd Date, s String', '2020010h,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:50.522286 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020010h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:50.624107 [ 8431 ] {4f307c6f-8f81-4cb5-9163-002a708f9a05} executeQuery: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 0, should be 3: In scope SELECT translateUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1511, line 1516) (in query: SELECT translateUTF8();) 2025.06.13 15:45:50.632538 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 0, should be 3: In scope SELECT translateUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:50.696593 [ 5978 ] {714092c3-ea77-48b9-b4d8-80c9fa902f0d} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1237, line 1239) (in query: SELECT sparkBar(-1);) 2025.06.13 15:45:50.740084 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:50.758858 [ 7279 ] {df57e5fd-06e3-475e-af26-8dca892b46bd} executeQuery: Code: 119. DB::Exception: Table engine is not specified in CREATE query. (ENGINE_REQUIRED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54296) (comment: 02184_default_table_engine.sql) (query 2, line 3) (in query: CREATE TABLE table_02184 (x UInt8);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1170: DB::(anonymous namespace)::setDefaultTableEngine(DB::ASTStorage&, DB::DefaultTableEngine) @ 0x000000002dc6ca8b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1384: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x000000002dc67f63 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5de9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:50.758953 [ 8431 ] {7a3cc4bd-63fb-44ba-a09c-f647fcb5dc0f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimBoth'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT trimBoth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1512, line 1518) (in query: SELECT trimBoth();) 2025.06.13 15:45:50.763900 [ 7279 ] {} TCPHandler: Code: 119. DB::Exception: Table engine is not specified in CREATE query. (ENGINE_REQUIRED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1170: DB::(anonymous namespace)::setDefaultTableEngine(DB::ASTStorage&, DB::DefaultTableEngine) @ 0x000000002dc6ca8b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1384: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x000000002dc67f63 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5de9a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:50.764444 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimBoth'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT trimBoth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:50.825798 [ 8431 ] {f90fdee7-566e-4c2d-8975-b1abaf510cfb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimLeft'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT trimLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1513, line 1519) (in query: SELECT trimLeft();) 2025.06.13 15:45:50.848529 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimLeft'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT trimLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:50.849269 [ 5978 ] {413a9340-b852-4bc9-8b67-b965db35bcf8} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1238, line 1240) (in query: SELECT sparkbar(-1);) 2025.06.13 15:45:50.851995 [ 18380 ] {88055f30-ac84-4c63-90f0-ba88c7fec534} executeQuery: Code: 38. DB::Exception: Cannot parse date here: abcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 10, line 10) (in query: select * from format(CSV, 'd Date, s String', 'abcd-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:50.858606 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: abcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:50.862042 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:50.920475 [ 18380 ] {36ee3ee9-132d-4ad0-85fe-fa632b558397} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2bcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 11, line 11) (in query: select * from format(CSV, 'd Date, s String', '2bcd-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:50.991235 [ 8431 ] {cb79a92c-13d4-453b-a15a-465b29d3eae2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimRight'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT trimRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1514, line 1520) (in query: SELECT trimRight();) 2025.06.13 15:45:50.993096 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2bcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:51.089280 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimRight'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT trimRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:51.101627 [ 5978 ] {07e0de47-d1ab-4fa2-8ad9-42828affa1a3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'alphaTokens'. Expected: String, got: Int8: In scope SELECT splitByAlpha(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1239, line 1241) (in query: SELECT splitByAlpha(-1);) 2025.06.13 15:45:51.115450 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'alphaTokens'. Expected: String, got: Int8: In scope SELECT splitByAlpha(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:51.196773 [ 8431 ] {c1ba44a6-e836-43d7-84eb-9ef368b39e54} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT trunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1515, line 1521) (in query: SELECT trunc();) 2025.06.13 15:45:51.196913 [ 18380 ] {ae869bd9-2882-4c86-8521-a6b37dfe866b} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 20cd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 12, line 12) (in query: select * from format(CSV, 'd Date, s String', '20cd-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:51.210746 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT trunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:51.216615 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 20cd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:51.232145 [ 5978 ] {633dde32-36f4-419e-87d5-b7006aee6093} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByChar'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT splitByChar(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1240, line 1242) (in query: SELECT splitByChar(-1);) 2025.06.13 15:45:51.257746 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByChar'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT splitByChar(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:51.354169 [ 8431 ] {6eb0ac26-0bb9-4791-afbe-3be451046cfc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT truncate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1516, line 1522) (in query: SELECT truncate();) 2025.06.13 15:45:51.381364 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT truncate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:51.388744 [ 18380 ] {3e3f46ca-6296-4cfe-b78b-a8828f83a73a} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 202d-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 13, line 13) (in query: select * from format(CSV, 'd Date, s String', '202d-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:51.403180 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 202d-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:51.418020 [ 5978 ] {1d5e1789-4135-4ef2-88c7-9e1617bd6575} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'splitByNonAlpha'. Expected: String, got: Int8: In scope SELECT splitByNonAlpha(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1241, line 1243) (in query: SELECT splitByNonAlpha(-1);) 2025.06.13 15:45:51.427057 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'splitByNonAlpha'. Expected: String, got: Int8: In scope SELECT splitByNonAlpha(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:51.494994 [ 8431 ] {5603e787-a08a-41ef-aa9b-15a76d9f51ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 0, should be 1: In scope SELECT tryBase58Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1517, line 1523) (in query: SELECT tryBase58Decode();) 2025.06.13 15:45:51.512012 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 0, should be 1: In scope SELECT tryBase58Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:51.515996 [ 18380 ] {57192480-f2fa-4c4a-a659-8b868a03d258} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 14, line 14) (in query: select * from format(CSV, 'd Date, s String', '2020-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:51.520356 [ 5978 ] {5becc734-aa31-4b4b-adcb-8f8832bc5323} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByRegexp'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT splitByRegexp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1242, line 1244) (in query: SELECT splitByRegexp(-1);) 2025.06.13 15:45:51.540229 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByRegexp'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT splitByRegexp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:51.544674 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:51.650286 [ 8431 ] {7ec55086-38ea-49c1-b49e-41388e9252e1} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1518, line 1524) (in query: SELECT tryBase64Decode();) 2025.06.13 15:45:51.650337 [ 5978 ] {fa9e3ae7-3351-4808-8ebd-183e0d29e3c8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByString'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT splitByString(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1243, line 1245) (in query: SELECT splitByString(-1);) 2025.06.13 15:45:51.650791 [ 18380 ] {a62b6f07-b4b5-41b2-8d4b-fdc40bf9a4d2} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-f-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 15, line 15) (in query: select * from format(CSV, 'd Date, s String', '2020-f-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:51.654790 [ 8431 ] {} 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) 2025.06.13 15:45:51.656677 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-f-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:51.657970 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByString'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT splitByString(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:51.763422 [ 8431 ] {f22a4c6b-b2e8-48de-b18a-224ec2ceb3da} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 0, should be 1: In scope SELECT tryBase64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1519, line 1525) (in query: SELECT tryBase64URLDecode();) 2025.06.13 15:45:51.764831 [ 7279 ] {18eb5d72-8ad7-48bc-840f-4b7616cabf3e} executeQuery: Code: 42. DB::Exception: ORDER BY or PRIMARY KEY clause is missing. Consider using extended storage definition syntax with ORDER BY or PRIMARY KEY clause. With deprecated old syntax (highly not recommended) storage MergeTree requires 3 to 4 parameters: name of column with date, [sampling element of primary key], primary key expression, index granularity Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54296) (comment: 02184_default_table_engine.sql) (query 8, line 10) (in query: CREATE TABLE table_02184 (x UInt8);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x00000000311c35cf 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:502: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c0265 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:51.779746 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 0, should be 1: In scope SELECT tryBase64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:51.784534 [ 7279 ] {} TCPHandler: Code: 42. DB::Exception: ORDER BY or PRIMARY KEY clause is missing. Consider using extended storage definition syntax with ORDER BY or PRIMARY KEY clause. With deprecated old syntax (highly not recommended) storage MergeTree requires 3 to 4 parameters: name of column with date, [sampling element of primary key], primary key expression, index granularity Syntax for the MergeTree table engine: CREATE TABLE [IF NOT EXISTS] [db.]table_name [ON CLUSTER cluster] ( name1 [type1] [DEFAULT|MATERIALIZED|ALIAS expr1] [TTL expr1], name2 [type2] [DEFAULT|MATERIALIZED|ALIAS expr2] [TTL expr2], ... INDEX index_name1 expr1 TYPE type1(...) [GRANULARITY value1], INDEX index_name2 expr2 TYPE type2(...) [GRANULARITY value2] ) ENGINE = MergeTree() ORDER BY expr [PARTITION BY expr] [PRIMARY KEY expr] [SAMPLE BY expr] [TTL expr [DELETE|TO DISK 'xxx'|TO VOLUME 'xxx'], ...] [SETTINGS name=value, ...] [COMMENT 'comment'] See details in documentation: https://clickhouse.com/docs/engines/table-engines/mergetree-family/mergetree/. Other engines of the family support different syntax, see details in the corresponding documentation topics. If you use the Replicated version of engines, see https://clickhouse.com/docs/engines/table-engines/mergetree-family/replication/. . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, char const* const&) @ 0x00000000311c35cf 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:502: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311c0265 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:51.787854 [ 18380 ] {2e1368e7-885b-4ba4-af33-3b7b26ca5824} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-f-g,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 16, line 16) (in query: select * from format(CSV, 'd Date, s String', '2020-f-g,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:51.812460 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-f-g,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:51.812990 [ 5978 ] {76c518d5-cc04-442c-8f83-964e8674cbfd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'splitByWhitespace'. Expected: String, got: Int8: In scope SELECT splitByWhitespace(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1244, line 1246) (in query: SELECT splitByWhitespace(-1);) 2025.06.13 15:45:51.852241 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'splitByWhitespace'. Expected: String, got: Int8: In scope SELECT splitByWhitespace(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:51.918378 [ 8431 ] {99f4e90c-0e0b-4878-ab5d-de6ea7b6b1cf} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'tryDecrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT tryDecrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1520, line 1526) (in query: SELECT tryDecrypt();) 2025.06.13 15:45:51.933563 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'tryDecrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT tryDecrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:51.965687 [ 18380 ] {a46f0952-864a-459d-8b75-c53c4c162fb0} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-0f-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 17, line 17) (in query: select * from format(CSV, 'd Date, s String', '2020-0f-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:51.976452 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-0f-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:51.980572 [ 5978 ] {2af3cbfc-5a7a-4bb7-bd71-f86b3853f176} executeQuery: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Int8.: In scope SELECT sqid(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1245, line 1247) (in query: SELECT sqid(-1);) 2025.06.13 15:45:51.994614 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Int8.: In scope SELECT sqid(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:52.089337 [ 8431 ] {220b6877-6fe5-404b-a5cc-63aa844a12bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 0, should be 1: In scope SELECT tryIdnaEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1521, line 1527) (in query: SELECT tryIdnaEncode();) 2025.06.13 15:45:52.096470 [ 7279 ] {27876282-d9ab-41ea-9dd9-9697e7ad809d} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54296) (comment: 02184_default_table_engine.sql) (query 9, line 11) (in query: CREATE TABLE table_02184 (x UInt8, PRIMARY KEY (x));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:45:52.096834 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 0, should be 1: In scope SELECT tryIdnaEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:52.122900 [ 7279 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:45:52.135514 [ 18380 ] {066f2afd-d750-401d-a982-7e2556445d6c} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-01-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 18, line 18) (in query: select * from format(CSV, 'd Date, s String', '2020-01-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:52.145958 [ 5978 ] {b30e1a14-07ee-4e83-a4f9-4e50efe5dfa1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'sqid' to function 'sqidDecode'. Expected: String, got: Int8: In scope SELECT sqidDecode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1246, line 1248) (in query: SELECT sqidDecode(-1);) 2025.06.13 15:45:52.148353 [ 3895 ] {e174d243-e282-4fdf-a085-95bb20260844} executeQuery: Code: 43. DB::Exception: Nested type Tuple(UInt64, UInt64) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54388) (comment: 02922_respect_nulls_Nullable.sql) (query 2, line 37) (in query: -- { echoOn } Select anyOrNull(tp) FROM (Select (number, number) as tp from numbers(10));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x000000002c43cd5d 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::allocator, 0>(std::allocator, std::shared_ptr const&) @ 0x000000002846a5d9 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x000000002846a3e0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::AggregateFunctionOrFill::createResultType(std::shared_ptr const&) @ 0x0000000028464948 9. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:37: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846440d 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107] const&, std::vector, std::allocator>> const&, DB::Array const&, std::allocator>, 0>(std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846408b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028463e6c 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028463d71 13. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4987 14. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:45:52.149301 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-01-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:52.162964 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'sqid' to function 'sqidDecode'. Expected: String, got: Int8: In scope SELECT sqidDecode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:52.163135 [ 3895 ] {} TCPHandler: Code: 43. DB::Exception: Nested type Tuple(UInt64, UInt64) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x000000002c43cd5d 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::allocator, 0>(std::allocator, std::shared_ptr const&) @ 0x000000002846a5d9 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x000000002846a3e0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::AggregateFunctionOrFill::createResultType(std::shared_ptr const&) @ 0x0000000028464948 9. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:37: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846440d 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107] const&, std::vector, std::allocator>> const&, DB::Array const&, std::allocator>, 0>(std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846408b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028463e6c 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028463d71 13. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4987 14. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:45:52.227332 [ 8431 ] {1d896927-faf0-4e38-a6fb-527d260ba9e5} 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.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1522, line 1528) (in query: SELECT tryPunycodeDecode();) 2025.06.13 15:45:52.244956 [ 8431 ] {} 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) 2025.06.13 15:45:52.257067 [ 18380 ] {bfc67c89-dcba-4593-b0cb-c67ec464ea9b} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-01-h,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 19, line 19) (in query: select * from format(CSV, 'd Date, s String', '2020-01-h,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:52.268384 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-01-h,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:52.355496 [ 3895 ] {19dbd086-238b-4211-b6bc-e6a4d42d1000} executeQuery: Code: 43. DB::Exception: Nested type Tuple(UInt64, UInt64) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54388) (comment: 02922_respect_nulls_Nullable.sql) (query 3, line 39) (in query: Select anyOrNull(tp) FROM (Select (number, number) as tp from numbers(10));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x000000002c43cd5d 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::allocator, 0>(std::allocator, std::shared_ptr const&) @ 0x000000002846a5d9 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x000000002846a3e0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::AggregateFunctionOrFill::createResultType(std::shared_ptr const&) @ 0x0000000028464948 9. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:37: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846440d 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107] const&, std::vector, std::allocator>> const&, DB::Array const&, std::allocator>, 0>(std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846408b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028463e6c 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028463d71 13. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4987 14. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:45:52.356971 [ 5978 ] {ed43752b-9532-42b2-ad3c-701b97dbcf24} executeQuery: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Int8.: In scope SELECT sqidEncode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1247, line 1249) (in query: SELECT sqidEncode(-1);) 2025.06.13 15:45:52.366826 [ 3895 ] {} TCPHandler: Code: 43. DB::Exception: Nested type Tuple(UInt64, UInt64) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x000000002c43cd5d 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::allocator, 0>(std::allocator, std::shared_ptr const&) @ 0x000000002846a5d9 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x000000002846a3e0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::AggregateFunctionOrFill::createResultType(std::shared_ptr const&) @ 0x0000000028464948 9. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:37: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846440d 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace, std::allocator>>::__shared_ptr_emplace[abi:ne190107] const&, std::vector, std::allocator>> const&, DB::Array const&, std::allocator>, 0>(std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002846408b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000028463e6c 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000028463d71 13. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4987 14. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:45:52.374630 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Int8.: In scope SELECT sqidEncode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:52.376201 [ 8431 ] {6a78d333-30d0-4341-8f12-0a413826b755} executeQuery: Code: 42. DB::Exception: Number of arguments for function tumble doesn't match: passed 0, should be 2 or 3: In scope SELECT tumble(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1523, line 1529) (in query: SELECT tumble();) 2025.06.13 15:45:52.409465 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tumble doesn't match: passed 0, should be 2 or 3: In scope SELECT tumble(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:52.421895 [ 18380 ] {6259a0de-1bfc-4713-809d-7ccf544d0b05} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-1-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 20, line 20) (in query: select * from format(CSV, 'd Date, s String', '2020-1-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:52.438760 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-1-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:52.617689 [ 8431 ] {6623b11f-3ab6-4994-bfbc-a4c0c18f0c04} executeQuery: Code: 42. DB::Exception: Number of arguments for function tumbleEnd doesn't match: passed 0, should be 2 or 3: In scope SELECT tumbleEnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1524, line 1530) (in query: SELECT tumbleEnd();) 2025.06.13 15:45:52.632777 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tumbleEnd doesn't match: passed 0, should be 2 or 3: In scope SELECT tumbleEnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:52.660888 [ 18380 ] {3fca0731-c102-4ab6-9f4d-6429f66ef498} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-1-h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54210) (comment: 02916_date_text_parsing.sql) (query 21, line 21) (in query: select * from format(CSV, 'd Date, s String', '2020-1-h,SomeString');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:52.664835 [ 18380 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-1-h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing CSVRowInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000028946d98 5. ./src/IO/ReadHelpers.h:0: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000028946a97 6. ./src/IO/ReadHelpers.h:850: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x000000002c54e915 7. ./src/IO/ReadHelpers.h:1629: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c54e3d9 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:772: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002c5e2f99 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:386: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x00000000319db406 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003196a5b1 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 22. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 2025.06.13 15:45:52.691618 [ 5978 ] {28c90f04-b58f-433b-8092-372927a4507e} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 1, should be 2: In scope SELECT startsWith(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1249, line 1251) (in query: SELECT startsWith(-1);) 2025.06.13 15:45:52.695828 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 1, should be 2: In scope SELECT startsWith(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:52.712052 [ 8431 ] {f0e1aed7-c715-49a0-aae4-8132b5928b48} executeQuery: Code: 42. DB::Exception: Number of arguments for function tumbleStart doesn't match: passed 0, should be 2 or 3: In scope SELECT tumbleStart(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1525, line 1531) (in query: SELECT tumbleStart();) 2025.06.13 15:45:52.730135 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tumbleStart doesn't match: passed 0, should be 2 or 3: In scope SELECT tumbleStart(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:52.815273 [ 5978 ] {8251d1c4-7e03-4939-bd28-12730427a0ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 1, should be 2: In scope SELECT startsWithUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1250, line 1252) (in query: SELECT startsWithUTF8(-1);) 2025.06.13 15:45:52.826362 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 1, should be 2: In scope SELECT startsWithUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:53.112860 [ 8431 ] {0af7cdd9-c69e-4f5c-9388-4adedbdabca9} executeQuery: Code: 42. DB::Exception: Function tupleConcat requires at least one argument.: In scope SELECT tupleConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1527, line 1533) (in query: SELECT tupleConcat();) 2025.06.13 15:45:53.126307 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function tupleConcat requires at least one argument.: In scope SELECT tupleConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:53.244159 [ 8431 ] {e927f541-d2c3-4d02-abef-847379a98834} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 0, should be 2: In scope SELECT tupleDivide(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1528, line 1534) (in query: SELECT tupleDivide();) 2025.06.13 15:45:53.261572 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 0, should be 2: In scope SELECT tupleDivide(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:53.350776 [ 6193 ] {cfc815d0-62d3-4503-8f74-ef92a4b5b18b} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54466) (comment: 02842_move_pk_to_end_of_prewhere.sql) (query 5, line 7) (in query: CREATE TABLE t_02848_mt1 (`k` UInt32, `v` String) ENGINE = MergeTree ORDER BY k SETTINGS min_bytes_for_wide_part = 0, index_granularity = 35591, ratio_of_defaults_for_sparse_serialization = 0.05096041411161423, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 55491684, compact_parts_max_bytes_to_buffer = 20026609, compact_parts_max_granules_to_buffer = 49, compact_parts_merge_max_bytes_to_prefetch_part = 24221673, merge_max_block_size = 11587, old_parts_lifetime = 27., prefer_fetch_merged_part_size_threshold = 912526911, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 90, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 17791498, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 91723, primary_key_compress_block_size = 16313, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:45:53.368370 [ 6193 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:45:53.439376 [ 8431 ] {06eb503d-be39-4ea3-b62b-ad1ea56f673a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleDivideByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1529, line 1535) (in query: SELECT tupleDivideByNumber();) 2025.06.13 15:45:53.475747 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleDivideByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:53.591508 [ 8431 ] {5270ac6f-5e57-407d-88b2-deef526a2dd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 0, should be 2 or 3: In scope SELECT tupleElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1530, line 1536) (in query: SELECT tupleElement();) 2025.06.13 15:45:53.710337 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 0, should be 2 or 3: In scope SELECT tupleElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:53.724356 [ 3895 ] {8c12f0a3-1b93-4b22-b663-e94d86c32d7d} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nullsOrNull, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nullsOrNull instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54388) (comment: 02922_respect_nulls_Nullable.sql) (query 9, line 57) (in query: SELECT first_value_respect_nullsMerge(t) FROM (Select first_value_respect_nullsOrNullState(number) as t FROM numbers(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002841f157 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4987 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:45:53.740862 [ 3895 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nullsOrNull, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nullsOrNull instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002841f157 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4987 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:45:53.769198 [ 8431 ] {723f6176-209a-457b-8d6e-022595c52432} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 0, should be 2: In scope SELECT tupleHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1531, line 1537) (in query: SELECT tupleHammingDistance();) 2025.06.13 15:45:53.774766 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 0, should be 2: In scope SELECT tupleHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:53.865925 [ 3895 ] {93946b4b-3a41-495a-9522-820a2c0effcd} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nulls instead of any_respect_nullsOrNull. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54388) (comment: 02922_respect_nulls_Nullable.sql) (query 10, line 58) (in query: SELECT first_value_respect_nullsOrNullMerge(t) FROM (Select first_value_respect_nullsState(number) as t FROM numbers(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002841f157 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4987 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:45:53.873149 [ 8431 ] {95bf55c3-6c7e-4ef2-9474-0321598ca466} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 0, should be 2: In scope SELECT tupleIntDiv(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1532, line 1538) (in query: SELECT tupleIntDiv();) 2025.06.13 15:45:53.873682 [ 3895 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nulls instead of any_respect_nullsOrNull. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002841f157 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002b3c4987 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:45:53.877847 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 0, should be 2: In scope SELECT tupleIntDiv(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:54.059748 [ 8431 ] {424ccfdf-8404-43b6-af00-f7eb47fb3e35} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1533, line 1539) (in query: SELECT tupleIntDivByNumber();) 2025.06.13 15:45:54.065506 [ 5978 ] {cc9ea5e8-c0a4-45f9-aa13-4c4f47d6f461} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1255, line 1257) (in query: SELECT stem(-1);) 2025.06.13 15:45:54.069124 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:54.086800 [ 5978 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:45:54.163995 [ 8431 ] {a02a5918-b8a3-46f5-97b8-91efc760e6e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1534, line 1540) (in query: SELECT tupleIntDivOrZero();) 2025.06.13 15:45:54.170702 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:54.228203 [ 5978 ] {d3dbe9d0-086a-46c0-871c-5af864b5bf6d} executeQuery: Code: 35. DB::Exception: Aggregate function stochasticLinearRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1256, line 1258) (in query: SELECT stochasticLinearRegression(-1);) 2025.06.13 15:45:54.241879 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function stochasticLinearRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:45:54.264358 [ 5163 ] {349bc470-cbf7-48b7-b5ad-aa055a020dcc} executeQuery: Code: 57. DB::Exception: Directory for table data data/test_7/test/ already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48316) (comment: 01442_date_time_with_params.sql) (query 2, line 3) (in query: CREATE TABLE test (`a` DateTime, `b` DateTime, `c` DateTime(2), `d` DateTime('Asia/Istanbul'), `e` DateTime(3, 'Asia/Istanbul'), `f` DateTime32, `g` DateTime32('Asia/Istanbul'), `h` DateTime(0)) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 14640, min_bytes_for_wide_part = 245297135, 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 = 354159169, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 22485079, merge_max_block_size = 1686, old_parts_lifetime = 164., prefer_fetch_merged_part_size_threshold = 10546560442, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 19918448, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 54, 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 = 33033, primary_key_compress_block_size = 60207, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:45:54.279744 [ 5163 ] {} TCPHandler: Code: 57. DB::Exception: Directory for table data data/test_7/test/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:45:54.317633 [ 8431 ] {dbb082cf-7367-4fbb-bf4e-f8186ef1479e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1535, line 1541) (in query: SELECT tupleIntDivOrZeroByNumber();) 2025.06.13 15:45:54.341146 [ 8432 ] {df719efb-2e2d-41e5-9339-8935216fcbe4} executeQuery: Code: 128. DB::Exception: Too large array size: 9223372036854775808, maximum: 1073741824: In scope SELECT arrayResize([1, 2, 3], -9223372036854775808). (TOO_LARGE_ARRAY_SIZE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48336) (comment: 01682_gather_utils_ubsan.sql) (query 1, line 1) (in query: SELECT arrayResize([1, 2, 3], -9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000018f1354f 5. void DB::GatherUtils::resizeDynamicSize&, DB::GatherUtils::ConstSource>&, DB::GatherUtils::NumericArraySink&>(DB::GatherUtils::NumericArraySource&, DB::GatherUtils::ConstSource>&, DB::GatherUtils::NumericArraySink&, DB::IColumn const&) @ 0x000000002d3de99f 6. DB::GatherUtils::resizeDynamicSize(DB::GatherUtils::IArraySource&, DB::GatherUtils::IValueSource&, DB::GatherUtils::IArraySink&, DB::IColumn const&) @ 0x000000002d296140 7. ./build_docker/./src/Functions/array/arrayResize.cpp:113: DB::FunctionArrayResize::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d16f1b0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:45:54.357504 [ 8432 ] {} TCPHandler: Code: 128. DB::Exception: Too large array size: 9223372036854775808, maximum: 1073741824: In scope SELECT arrayResize([1, 2, 3], -9223372036854775808). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000018f1354f 5. void DB::GatherUtils::resizeDynamicSize&, DB::GatherUtils::ConstSource>&, DB::GatherUtils::NumericArraySink&>(DB::GatherUtils::NumericArraySource&, DB::GatherUtils::ConstSource>&, DB::GatherUtils::NumericArraySink&, DB::IColumn const&) @ 0x000000002d3de99f 6. DB::GatherUtils::resizeDynamicSize(DB::GatherUtils::IArraySource&, DB::GatherUtils::IValueSource&, DB::GatherUtils::IArraySink&, DB::IColumn const&) @ 0x000000002d296140 7. ./build_docker/./src/Functions/array/arrayResize.cpp:113: DB::FunctionArrayResize::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d16f1b0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:45:54.364380 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:54.389667 [ 5978 ] {70d8d9a4-1c2c-44dc-9ce3-12ed007bbab6} executeQuery: Code: 35. DB::Exception: Aggregate function stochasticLogisticRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1257, line 1259) (in query: SELECT stochasticLogisticRegression(-1);) 2025.06.13 15:45:54.397509 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: Aggregate function stochasticLogisticRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:45:54.521672 [ 5978 ] {6fa506c5-144f-4f0a-a750-93685c0b8bcd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Int8: In scope SELECT str_to_date(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1258, line 1260) (in query: SELECT str_to_date(-1);) 2025.06.13 15:45:54.527705 [ 8431 ] {77abb29c-ef2b-49e9-adb6-2a55ca55b9a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 0, should be 2: In scope SELECT tupleMinus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1536, line 1542) (in query: SELECT tupleMinus();) 2025.06.13 15:45:54.539126 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 0, should be 2: In scope SELECT tupleMinus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:54.579693 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Int8: In scope SELECT str_to_date(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:54.631169 [ 8101 ] {3e69511e-dd37-4485-b0e6-b770faf90261} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 212, line 212) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:54.641626 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:54.673531 [ 8431 ] {bebd61eb-3072-4bd1-bdfa-870fdb42c899} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 0, should be 2: In scope SELECT tupleModulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1537, line 1543) (in query: SELECT tupleModulo();) 2025.06.13 15:45:54.676366 [ 5978 ] {c74fef69-5d85-4188-b261-0632e7fbfd2c} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument data_column. Must be String.: In scope SELECT str_to_map(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1259, line 1261) (in query: SELECT str_to_map(-1);) 2025.06.13 15:45:54.677614 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 0, should be 2: In scope SELECT tupleModulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:54.694511 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument data_column. Must be String.: In scope SELECT str_to_map(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:54.743650 [ 8101 ] {b0e856fc-eca5-4ce1-a09b-e3f36c54c3e3} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 213, line 213) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:54.753937 [ 8431 ] {af0fc4e3-bf9f-4d5e-81f8-b786b6f5d9cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleModuloByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1538, line 1544) (in query: SELECT tupleModuloByNumber();) 2025.06.13 15:45:54.770788 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleModuloByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:54.778987 [ 5978 ] {1e7996e6-4722-4c73-ba64-755cf55d59cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 1, should be 2: In scope SELECT stringJaccardIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1260, line 1262) (in query: SELECT stringJaccardIndex(-1);) 2025.06.13 15:45:54.794221 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 1, should be 2: In scope SELECT stringJaccardIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:54.808372 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:54.920935 [ 8431 ] {85a6b771-c5df-44bd-89cf-bc423c30df04} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 0, should be 2: In scope SELECT tupleMultiply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1539, line 1545) (in query: SELECT tupleMultiply();) 2025.06.13 15:45:54.927392 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 0, should be 2: In scope SELECT tupleMultiply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:54.947308 [ 5978 ] {5baf5ee7-14f2-44d0-9e52-9c1b49e7d968} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 1, should be 2: In scope SELECT stringJaccardIndexUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1261, line 1263) (in query: SELECT stringJaccardIndexUTF8(-1);) 2025.06.13 15:45:55.004334 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 1, should be 2: In scope SELECT stringJaccardIndexUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:55.017387 [ 8101 ] {fb9b573a-7aa1-421f-912e-75f60a07819d} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 214, line 214) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:55.022184 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:55.029348 [ 8431 ] {7c7351b0-a348-415c-8610-53d1729f64f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleMultiplyByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1540, line 1546) (in query: SELECT tupleMultiplyByNumber();) 2025.06.13 15:45:55.099779 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleMultiplyByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:55.110937 [ 5978 ] {4d7c43c4-9871-4e66-939d-1188c03f12d4} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function stringToH3. Must be String or FixedString: In scope SELECT stringToH3(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1262, line 1264) (in query: SELECT stringToH3(-1);) 2025.06.13 15:45:55.224022 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function stringToH3. Must be String or FixedString: In scope SELECT stringToH3(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:55.269113 [ 8431 ] {7521aedf-8c57-465a-ae11-37b93493059c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 0, should be 1: In scope SELECT tupleNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1541, line 1547) (in query: SELECT tupleNames();) 2025.06.13 15:45:55.301203 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 0, should be 1: In scope SELECT tupleNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:55.301390 [ 3931 ] {8cd83027-d066-4f45-a235-5719d1b0b1d1} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48374) (comment: 03033_virtual_column_override.sql) (query 2, line 2) (in query: CREATE TABLE override_test (`_part` UInt32) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 4785, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 321381483, compact_parts_max_bytes_to_buffer = 34920059, compact_parts_max_granules_to_buffer = 10, compact_parts_merge_max_bytes_to_prefetch_part = 5681446, merge_max_block_size = 10502, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 4773312621, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9799902827, index_granularity_bytes = 1531238, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 55, 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 = 17808, primary_key_compress_block_size = 63887, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true AS SELECT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:55.340184 [ 3931 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:45:55.350225 [ 5978 ] {bd438598-8e38-4df3-89a2-a0ff7997b91a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of the first argument of function structureToCapnProtoSchema, expected constant string: In scope SELECT structureToCapnProtoSchema(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1263, line 1265) (in query: SELECT structureToCapnProtoSchema(-1);) 2025.06.13 15:45:55.387679 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of the first argument of function structureToCapnProtoSchema, expected constant string: In scope SELECT structureToCapnProtoSchema(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:55.450040 [ 8431 ] {409adab6-2ecc-4145-95b0-e41a4913f56c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 0, should be 1: In scope SELECT tupleNegate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1542, line 1548) (in query: SELECT tupleNegate();) 2025.06.13 15:45:55.455058 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 0, should be 1: In scope SELECT tupleNegate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:55.527071 [ 5978 ] {0983dd02-6525-41e0-9304-d1623e867628} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of the first argument of function structureToProtobufSchema, expected constant string: In scope SELECT structureToProtobufSchema(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1264, line 1266) (in query: SELECT structureToProtobufSchema(-1);) 2025.06.13 15:45:55.545561 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of the first argument of function structureToProtobufSchema, expected constant string: In scope SELECT structureToProtobufSchema(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:55.546410 [ 8431 ] {f8a70a4e-c0c9-4a2b-858d-c3b398725554} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 0, should be 2: In scope SELECT tuplePlus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1543, line 1549) (in query: SELECT tuplePlus();) 2025.06.13 15:45:55.553380 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 0, should be 2: In scope SELECT tuplePlus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:55.582466 [ 8101 ] {c0c60f3c-0351-4838-afff-6aaca6b1c723} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 217, line 217) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:55.591905 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:55.666533 [ 8431 ] {c290c5ad-8ea2-4fcc-86b4-eda3da3ca643} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 0, should be 1: In scope SELECT tupleToNameValuePairs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1544, line 1550) (in query: SELECT tupleToNameValuePairs();) 2025.06.13 15:45:55.678226 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 0, should be 1: In scope SELECT tupleToNameValuePairs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:55.729803 [ 8101 ] {90a83d6f-d82f-4454-abbf-5cc91a706a60} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 218, line 218) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:55.737676 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:55.755388 [ 5978 ] {24605479-fb1f-40a1-8738-9332c79c0223} executeQuery: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1265, line 1267) (in query: SELECT studentTTest(-1);) 2025.06.13 15:45:55.759581 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:55.791293 [ 8431 ] {9c49dfec-1451-4be1-85f4-e1ea07135b79} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 0, should be 1: In scope SELECT ucase(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1545, line 1551) (in query: SELECT ucase();) 2025.06.13 15:45:55.797009 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 0, should be 1: In scope SELECT ucase(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:55.834011 [ 5978 ] {f344f11a-28c4-4f87-b79b-505d90a0eb38} executeQuery: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 1, should be 3: In scope SELECT subBitmap(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1266, line 1268) (in query: SELECT subBitmap(-1);) 2025.06.13 15:45:55.854837 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 1, should be 3: In scope SELECT subBitmap(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:55.866187 [ 8101 ] {c68e1383-5f05-4929-9b78-361e29d4f12e} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 219, line 219) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:55.892217 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:55.898391 [ 8431 ] {f0b7ddd2-d5f4-4119-9329-4c837b9aff61} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 0, should be 1: In scope SELECT unbin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1546, line 1552) (in query: SELECT unbin();) 2025.06.13 15:45:55.902489 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 0, should be 1: In scope SELECT unbin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:55.966856 [ 5978 ] {ab8ae95e-0f98-44fe-97ca-4c8730704ec6} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 1, should be 2: In scope SELECT subDate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1267, line 1269) (in query: SELECT subDate(-1);) 2025.06.13 15:45:55.979517 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 1, should be 2: In scope SELECT subDate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:56.005990 [ 8431 ] {930182af-5ec9-4888-adf4-91d16120dbfb} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 0, should be 1: In scope SELECT unhex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1547, line 1553) (in query: SELECT unhex();) 2025.06.13 15:45:56.043256 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 0, should be 1: In scope SELECT unhex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:56.128776 [ 5978 ] {8bfa758b-1c22-46a4-8060-d775d1ac9eec} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 1, should be 2 or 3: In scope SELECT substr(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1268, line 1270) (in query: SELECT substr(-1);) 2025.06.13 15:45:56.144591 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 1, should be 2 or 3: In scope SELECT substr(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:56.162810 [ 8431 ] {2b46f84b-611d-43a8-8591-1e351ea6d05a} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniq. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1548, line 1554) (in query: SELECT uniq();) 2025.06.13 15:45:56.188378 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniq. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:56.232357 [ 5978 ] {c778ea5a-44e8-4ded-a116-9197023d6fe5} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 1, should be 3: In scope SELECT substringIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1269, line 1272) (in query: SELECT substringIndex(-1);) 2025.06.13 15:45:56.243552 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 1, should be 3: In scope SELECT substringIndex(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:56.324303 [ 8431 ] {42ff1d79-d010-4079-9ccd-834c993dee19} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqCombined. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1549, line 1555) (in query: SELECT uniqCombined();) 2025.06.13 15:45:56.346138 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqCombined. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:56.379429 [ 5978 ] {fd34387d-88d7-460c-b450-2a316bc9a51e} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 1, should be 3: In scope SELECT substringIndexUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1270, line 1273) (in query: SELECT substringIndexUTF8(-1);) 2025.06.13 15:45:56.384357 [ 8101 ] {d8c8c782-e446-4936-9e52-ac3d5d34816a} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function timeSlot: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), timeSlot(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 222, line 222) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), timeSlot(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:45:56.487503 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 1, should be 3: In scope SELECT substringIndexUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:56.494274 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function timeSlot: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), timeSlot(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:56.501544 [ 8431 ] {9f8b0896-aaa9-4dc7-a98c-c6481c3370e4} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqCombined64. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1550, line 1556) (in query: SELECT uniqCombined64();) 2025.06.13 15:45:56.524084 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqCombined64. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:56.536632 [ 5112 ] {b104b27c-cf2c-4854-a5e0-157b6587699a} executeQuery: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48448) (comment: 02835_parallel_replicas_over_distributed.sql) (query 4, line 6) (in query: CREATE TABLE test (`id` UInt64, `date` Date) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 9373, min_bytes_for_wide_part = 0, 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 = 298783280, compact_parts_max_bytes_to_buffer = 489094429, compact_parts_max_granules_to_buffer = 214, compact_parts_merge_max_bytes_to_prefetch_part = 4910271, merge_max_block_size = 1056, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 63, min_merge_bytes_to_use_direct_io = 4689426629, index_granularity_bytes = 16835181, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 52, 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 = 81722, primary_key_compress_block_size = 60648, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:45:56.547229 [ 5112 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:45:56.585955 [ 5978 ] {ae509522-6129-433d-bc16-aeda06a1ce85} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT substringUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1271, line 1274) (in query: SELECT substringUTF8(-1);) 2025.06.13 15:45:56.590379 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringUTF8 doesn't match: passed 1, should be 2 or 3: In scope SELECT substringUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:56.711945 [ 8431 ] {75315ac8-f1c0-4fa4-aeb3-e7610746b546} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqExact. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1551, line 1557) (in query: SELECT uniqExact();) 2025.06.13 15:45:56.718208 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqExact. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:56.741298 [ 5978 ] {8b2915a8-eea8-41bc-a2e1-3716daccbd39} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractDays doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractDays(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1272, line 1275) (in query: SELECT subtractDays(-1);) 2025.06.13 15:45:56.752013 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractDays doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractDays(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:56.806190 [ 8431 ] {25d4bf4c-e5c7-4907-bd32-c45a6d8fdd00} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqHLL12. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1552, line 1558) (in query: SELECT uniqHLL12();) 2025.06.13 15:45:56.820439 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqHLL12. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:56.877225 [ 5978 ] {66b5c719-3634-45a1-9b6a-5b3a5184a2c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractHours doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractHours(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1273, line 1276) (in query: SELECT subtractHours(-1);) 2025.06.13 15:45:56.886270 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractHours doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractHours(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:56.992028 [ 5978 ] {d010cea0-0658-4dd6-8086-ac2d47858d08} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 1, should be 2: In scope SELECT subtractInterval(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1274, line 1277) (in query: SELECT subtractInterval(-1);) 2025.06.13 15:45:57.055397 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 1, should be 2: In scope SELECT subtractInterval(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:57.058553 [ 8431 ] {7856d978-d408-47e8-a7f0-e69cd694352a} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqTheta. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1553, line 1559) (in query: SELECT uniqTheta();) 2025.06.13 15:45:57.070694 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqTheta. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:57.127381 [ 5978 ] {166a4b75-3955-40ce-a0f2-8643ef6279b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMicroseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMicroseconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1275, line 1278) (in query: SELECT subtractMicroseconds(-1);) 2025.06.13 15:45:57.141764 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMicroseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMicroseconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:57.192450 [ 8431 ] {306d284d-1f4f-4dcb-9460-ff3adff2315b} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 0, should be 2: In scope SELECT uniqThetaIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1554, line 1560) (in query: SELECT uniqThetaIntersect();) 2025.06.13 15:45:57.217045 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 0, should be 2: In scope SELECT uniqThetaIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:57.273057 [ 5978 ] {147143d9-378f-4a86-94e4-5ec8e1c7920a} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMilliseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMilliseconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1276, line 1279) (in query: SELECT subtractMilliseconds(-1);) 2025.06.13 15:45:57.282714 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMilliseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMilliseconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:57.294309 [ 5110 ] {24b8381f-8d30-4a83-9714-3e2e72d4d237} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48482) (comment: 02179_degrees_radians.sql) (query 2, line 4) (in query: CREATE TABLE test_degs_to_rads (degrees Float64) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:45:57.313628 [ 8431 ] {b90285c0-f9fc-464a-8892-00b93ff767da} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 0, should be 2: In scope SELECT uniqThetaNot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1555, line 1561) (in query: SELECT uniqThetaNot();) 2025.06.13 15:45:57.313819 [ 5110 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:45:57.332478 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 0, should be 2: In scope SELECT uniqThetaNot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:57.403561 [ 5978 ] {707284b4-ea74-4e20-8e74-2bcb5274b0fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMinutes doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMinutes(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1277, line 1280) (in query: SELECT subtractMinutes(-1);) 2025.06.13 15:45:57.417390 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMinutes doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMinutes(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:57.452247 [ 8431 ] {c0f10ad3-35bb-48c5-b32d-d3baa0730372} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 0, should be 2: In scope SELECT uniqThetaUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1556, line 1562) (in query: SELECT uniqThetaUnion();) 2025.06.13 15:45:57.459399 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 0, should be 2: In scope SELECT uniqThetaUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:57.564255 [ 5978 ] {206dd746-a62f-4ad9-a563-3fed7b87a8fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMonths doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMonths(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1278, line 1281) (in query: SELECT subtractMonths(-1);) 2025.06.13 15:45:57.570968 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMonths doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractMonths(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:57.602057 [ 8431 ] {dbe656c7-b0f9-4d44-b612-6512ac61b1cd} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqUpTo. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1557, line 1563) (in query: SELECT uniqUpTo();) 2025.06.13 15:45:57.647189 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqUpTo. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:57.680058 [ 5978 ] {6083def8-5b4a-42ff-8e95-095101e63b0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractNanoseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractNanoseconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1279, line 1282) (in query: SELECT subtractNanoseconds(-1);) 2025.06.13 15:45:57.716625 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractNanoseconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractNanoseconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:57.764791 [ 8431 ] {88a95549-1a40-429c-98ac-5d760489b074} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 0, should be 1: In scope SELECT upper(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1558, line 1564) (in query: SELECT upper();) 2025.06.13 15:45:57.777877 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 0, should be 1: In scope SELECT upper(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:57.836797 [ 5978 ] {c276b700-4bae-46c4-8ce2-a388069ab1fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractQuarters doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractQuarters(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1280, line 1283) (in query: SELECT subtractQuarters(-1);) 2025.06.13 15:45:57.860906 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractQuarters doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractQuarters(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:57.928110 [ 5978 ] {5a11e0b0-c9a8-4ee9-964c-eb2c4de8f8e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractSeconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractSeconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1281, line 1284) (in query: SELECT subtractSeconds(-1);) 2025.06.13 15:45:57.941941 [ 8431 ] {e9703d5c-aa3c-4d1f-b359-f6470959a9dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 0, should be 1: In scope SELECT upperUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1559, line 1565) (in query: SELECT upperUTF8();) 2025.06.13 15:45:57.950955 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractSeconds doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractSeconds(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:57.965414 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 0, should be 1: In scope SELECT upperUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:58.061727 [ 5978 ] {f68ae162-621d-4e4e-9f06-7ec37848969c} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 1, should be 2: In scope SELECT subtractTupleOfIntervals(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1282, line 1285) (in query: SELECT subtractTupleOfIntervals(-1);) 2025.06.13 15:45:58.068197 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 1, should be 2: In scope SELECT subtractTupleOfIntervals(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:58.186469 [ 5978 ] {6907be35-78aa-4f70-9818-ab0c2c88a77b} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractWeeks doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractWeeks(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1283, line 1286) (in query: SELECT subtractWeeks(-1);) 2025.06.13 15:45:58.207860 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractWeeks doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractWeeks(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:58.539551 [ 5978 ] {74fb64aa-2f44-4789-b90d-a63af2783ed7} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractYears doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractYears(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1284, line 1287) (in query: SELECT subtractYears(-1);) 2025.06.13 15:45:58.544415 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractYears doesn't match: passed 1, should be 2 or 3: In scope SELECT subtractYears(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:58.592136 [ 8431 ] {8c65c76f-8604-4e42-b196-e700dc230db7} executeQuery: Code: 42. DB::Exception: Function validateNestedArraySizes needs more than two arguments; passed 0.: In scope SELECT validateNestedArraySizes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1562, line 1568) (in query: SELECT validateNestedArraySizes();) 2025.06.13 15:45:58.606918 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Function validateNestedArraySizes needs more than two arguments; passed 0.: In scope SELECT validateNestedArraySizes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:58.757300 [ 8431 ] {1f137b8c-586f-4ff3-ac72-a974a4f4057c} executeQuery: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1563, line 1569) (in query: SELECT varPop();) 2025.06.13 15:45:58.764124 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:58.841875 [ 8431 ] {56d83918-6b29-4925-8565-b2cc20372777} executeQuery: Code: 42. DB::Exception: Aggregate function varPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1564, line 1570) (in query: SELECT varPopStable();) 2025.06.13 15:45:58.860003 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:58.936787 [ 5110 ] {3decef16-6186-4175-8c8f-64f1ee4d764e} executeQuery: Poco::Exception. Code: 1000, e.code() = 0, Exception: Unsupported language for region name. Supported languages are: 'ru', 'en', 'ua', 'uk', 'by', 'kz', 'tr', 'de', 'uz', 'lv', 'lt', 'et', 'pt', 'he', 'vi', 'es'. (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48590) (comment: 02411_legacy_geobase.sql) (query 2, line 4) (in query: SELECT regionToName(number::UInt32, 'xy') FROM numbers(13);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:31: Poco::Exception::Exception(String&&, int) @ 0x00000000359971a0 2. DB::RegionsNames::getLanguageEnum(String const&) @ 0x0000000017f39f7d 3. DB::FunctionRegionToName::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f38ae0 4. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 14. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:45:58.948674 [ 5110 ] {} TCPHandler: Code: 1000. DB::Exception: Exception: Unsupported language for region name. Supported languages are: 'ru', 'en', 'ua', 'uk', 'by', 'kz', 'tr', 'de', 'uz', 'lv', 'lt', 'et', 'pt', 'he', 'vi', 'es'. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:31: Poco::Exception::Exception(String&&, int) @ 0x00000000359971a0 2. DB::RegionsNames::getLanguageEnum(String const&) @ 0x0000000017f39f7d 3. DB::FunctionRegionToName::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f38ae0 4. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 14. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 15. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 16. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:45:59.075384 [ 8431 ] {ceb66b44-21b6-40b5-bebe-936424e2ee6b} executeQuery: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1565, line 1571) (in query: SELECT varSamp();) 2025.06.13 15:45:59.088301 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:59.209390 [ 8431 ] {156256a3-168d-4b18-a0d9-230183719c17} executeQuery: Code: 42. DB::Exception: Aggregate function varSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1566, line 1572) (in query: SELECT varSampStable();) 2025.06.13 15:45:59.218108 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:59.293924 [ 5978 ] {9416a9cf-4c3a-40f6-bb34-1101bc8b5294} executeQuery: Code: 43. DB::Exception: When function sumMapFiltered gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1288, line 1291) (in query: SELECT sumMapFiltered(-1);) 2025.06.13 15:45:59.302970 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: When function sumMapFiltered gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:59.316195 [ 8431 ] {44b7dfe4-7323-4405-b315-d45afa507424} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantElement doesn't match: passed 0, should be 2 or 3: In scope SELECT variantElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1567, line 1573) (in query: SELECT variantElement();) 2025.06.13 15:45:59.343005 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantElement doesn't match: passed 0, should be 2 or 3: In scope SELECT variantElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:59.390134 [ 5978 ] {435bcf44-1f25-4182-a3c8-57f03be07d65} executeQuery: Code: 43. DB::Exception: When function sumMapFilteredWithOverflow gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1289, line 1292) (in query: SELECT sumMapFilteredWithOverflow(-1);) 2025.06.13 15:45:59.404329 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: When function sumMapFilteredWithOverflow gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:59.556156 [ 8431 ] {90209ee4-24e9-4c8c-b720-3d47bd8790bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 0, should be 1: In scope SELECT variantType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1568, line 1574) (in query: SELECT variantType();) 2025.06.13 15:45:59.579276 [ 5978 ] {a5172816-dbcf-46ed-ae0d-23cdf0cfc324} executeQuery: Code: 43. DB::Exception: When function sumMapWithOverflow gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1290, line 1293) (in query: SELECT sumMapWithOverflow(-1);) 2025.06.13 15:45:59.581389 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 0, should be 1: In scope SELECT variantType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:59.593326 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: When function sumMapWithOverflow gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:59.666676 [ 8431 ] {09b4c8c5-5b61-40a4-acff-c2e90443294d} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 0, should be 2: In scope SELECT vectorDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1569, line 1575) (in query: SELECT vectorDifference();) 2025.06.13 15:45:59.677438 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 0, should be 2: In scope SELECT vectorDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:45:59.702846 [ 5978 ] {9d6fb6f0-5069-47da-a0b2-fcdc495879ea} executeQuery: Code: 43. DB::Exception: When function sumMappedArrays gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1291, line 1294) (in query: SELECT sumMappedArrays(-1);) 2025.06.13 15:45:59.745027 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: When function sumMappedArrays gets one argument it must be a tuple. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:45:59.843869 [ 8431 ] {eb65fb61-4776-4fde-b6ea-64030111246d} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 0, should be 2: In scope SELECT vectorSum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1570, line 1576) (in query: SELECT vectorSum();) 2025.06.13 15:45:59.854347 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 0, should be 2: In scope SELECT vectorSum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:00.020741 [ 8430 ] {5f61dc42-ea25-4099-85fe-dd915104ff25} 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.20286.altinityantalya (altinity build)) (from [::1]:48708) (comment: 00765_locate.sql) (query 3, line 4) (in query: SELECT locate();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccaf6f 5. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001dc9cebd 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:46:00.047457 [ 8430 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccaf6f 5. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001dc9cebd 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:46:00.118343 [ 8431 ] {59b1fd1d-460e-4cd6-942b-134a6e64b63d} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 0, should be 1: In scope SELECT visibleWidth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1572, line 1578) (in query: SELECT visibleWidth();) 2025.06.13 15:46:00.129645 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 0, should be 1: In scope SELECT visibleWidth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:00.152536 [ 5978 ] {9192138e-ee0c-4cb3-9a15-3ca2f77ad1b1} executeQuery: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT svg(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1293, line 1296) (in query: SELECT svg(-1);) 2025.06.13 15:46:00.165551 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT svg(-1). (BAD_ARGUMENTS) 2025.06.13 15:46:00.296379 [ 8431 ] {d055d53d-c31f-4a3b-bc64-6c5cb6c47c2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1573, line 1579) (in query: SELECT visitParamExtractBool();) 2025.06.13 15:46:00.309618 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:00.366818 [ 5978 ] {fb90becd-34c3-4b44-a8a0-259d2d0b84ce} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1294, line 1297) (in query: SELECT synonyms(-1);) 2025.06.13 15:46:00.381289 [ 5978 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:46:00.398374 [ 8430 ] {2af1d31a-7eaf-4716-8a37-3c234ae79a93} 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.20286.altinityantalya (altinity build)) (from [::1]:48708) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001dc9d149 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:46:00.414098 [ 8430 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001dc9d149 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:46:00.436320 [ 8431 ] {e0f966c7-683c-4729-aa9c-f2068a8ae975} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1574, line 1580) (in query: SELECT visitParamExtractFloat();) 2025.06.13 15:46:00.446366 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:00.627928 [ 8430 ] {2788eec8-ed8f-462f-94fe-936ac400b44f} 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.20286.altinityantalya (altinity build)) (from [::1]:48708) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001dc9d2c9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:46:00.641368 [ 8431 ] {20d33d41-4055-4e9f-b264-ba29dd053686} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1575, line 1581) (in query: SELECT visitParamExtractInt();) 2025.06.13 15:46:00.652012 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:00.653375 [ 8430 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001dc9d2c9 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:46:00.681973 [ 8101 ] {9a55beaf-1438-4fcb-81f2-f6d0d8966267} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 242, line 242) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addYears(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:00.826010 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:00.867836 [ 8431 ] {cd0d674f-d05f-4c2e-91b5-417f7133f003} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1576, line 1582) (in query: SELECT visitParamExtractRaw();) 2025.06.13 15:46:00.874241 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:00.954162 [ 8430 ] {8c8a36f2-146a-4fee-acda-a54ad53e1249} 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.20286.altinityantalya (altinity build)) (from [::1]:48708) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001dc9d406 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:46:00.965424 [ 8430 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001dc9d406 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:46:00.993274 [ 8431 ] {08c8411a-d59e-4bb9-9619-a349c68c3555} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1577, line 1583) (in query: SELECT visitParamExtractString();) 2025.06.13 15:46:01.006457 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:01.066891 [ 5978 ] {e2a2157b-13b6-422e-b0f3-1082b8ddea7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 1, should be 0: In scope SELECT tcpPort(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1297, line 1300) (in query: SELECT tcpPort(-1);) 2025.06.13 15:46:01.078664 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 1, should be 0: In scope SELECT tcpPort(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:01.101872 [ 8431 ] {a5309990-cf68-4125-a8df-8e6413d98bd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1578, line 1584) (in query: SELECT visitParamExtractUInt();) 2025.06.13 15:46:01.117389 [ 3500 ] {b4c7e0c0-d1f3-4d4e-a03c-a209fabd39c5::all_1_1_0_2} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:01.136881 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:01.143912 [ 3500 ] {b4c7e0c0-d1f3-4d4e-a03c-a209fabd39c5::all_1_1_0_2} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:01.147116 [ 3500 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b4c7e0c0-d1f3-4d4e-a03c-a209fabd39c5::all_1_1_0_2}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:01.178230 [ 9642 ] {ab81a69e-a861-4962-9845-8000b5329913} 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: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x000000002e3722bf 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 . (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38548) (comment: 02461_prewhere_row_level_policy_lightweight_delete.gen.sql) (query 77, line 200) (in query: -- Delete more than a half rows (60K) from the range 2022-08-10 .. 2022-08-20 -- There should be 50K rows remaining in this range DELETE FROM url_na_log WHERE SiteId = 209 AND DateVisit >= '2022-08-13' AND DateVisit <= '2022-08-18';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x000000002e3722bf 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:46:01.181927 [ 5978 ] {f7e28f8a-de34-4101-8265-a28321b71a64} executeQuery: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 1, should be 2: In scope SELECT test_function(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1298, line 1301) (in query: SELECT test_function(-1);) 2025.06.13 15:46:01.221188 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 1, should be 2: In scope SELECT test_function(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:01.220121 [ 9642 ] {} 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: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x000000002e3722bf 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x000000002e3722bf 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:46:01.250124 [ 8431 ] {c15e1776-ba9e-4b69-bd74-dd2800465853} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 0, should be 2: In scope SELECT visitParamHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1579, line 1585) (in query: SELECT visitParamHas();) 2025.06.13 15:46:01.284782 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 0, should be 2: In scope SELECT visitParamHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:01.396183 [ 8431 ] {0fc3ec27-1a85-4538-86ee-a6a993081e6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT week(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1580, line 1586) (in query: SELECT week();) 2025.06.13 15:46:01.404256 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT week(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:01.578819 [ 8431 ] {8a073737-0e12-4506-868c-4c9281a58f0d} executeQuery: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1581, line 1587) (in query: SELECT welchTTest();) 2025.06.13 15:46:01.587579 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:01.590766 [ 5978 ] {2ec301ec-5db5-477c-92bd-e6a93591a510} executeQuery: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1300, line 1303) (in query: SELECT theilsU(-1);) 2025.06.13 15:46:01.598694 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:01.684202 [ 8431 ] {8b525dd0-4f96-4ff8-9336-af7d199dcc87} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 0, should be 4: In scope SELECT widthBucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1582, line 1588) (in query: SELECT widthBucket();) 2025.06.13 15:46:01.745500 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 0, should be 4: In scope SELECT widthBucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:01.773218 [ 5978 ] {11a7c751-09d9-4b1f-b5c7-585d9910bc49} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(-1_Int8 :: 1) -> throwIf(-1_Int8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1301, line 1304) (in query: SELECT throwIf(-1);) 2025.06.13 15:46:01.776633 [ 5978 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(-1_Int8 :: 1) -> throwIf(-1_Int8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) 2025.06.13 15:46:01.831652 [ 8431 ] {3e674e19-2187-40ca-b7b4-da22a98913fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 0, should be 4: In scope SELECT width_bucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1583, line 1589) (in query: SELECT width_bucket();) 2025.06.13 15:46:01.844702 [ 5978 ] {5dd4375e-1831-4192-b240-90b677782695} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 1, should be 0: In scope SELECT tid(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1302, line 1305) (in query: SELECT tid(-1);) 2025.06.13 15:46:01.851945 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 0, should be 4: In scope SELECT width_bucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:01.857917 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 1, should be 0: In scope SELECT tid(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:01.886014 [ 8101 ] {6740dfb4-a95f-4bdc-b9fb-770d3124880d} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 247, line 247) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addMonths(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:01.897422 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:01.934779 [ 8431 ] {ec45dbe2-3847-4e9c-a20d-8e76d5165a5e} executeQuery: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1584, line 1590) (in query: SELECT windowFunnel();) 2025.06.13 15:46:01.943753 [ 5978 ] {456288b1-01f8-415c-a044-9ce5b22a1768} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 1, should be 2: In scope SELECT timeDiff(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1303, line 1306) (in query: SELECT timeDiff(-1);) 2025.06.13 15:46:01.949981 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:01.969308 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 1, should be 2: In scope SELECT timeDiff(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:02.064609 [ 8431 ] {cd6eb815-b694-4bb8-b610-6aab48caba26} executeQuery: Code: 42. DB::Exception: Number of arguments for function windowID doesn't match: passed 0, should be 2, 3 or 4: In scope SELECT windowID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1585, line 1591) (in query: SELECT windowID();) 2025.06.13 15:46:02.070981 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function windowID doesn't match: passed 0, should be 2, 3 or 4: In scope SELECT windowID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:02.088763 [ 5978 ] {d6fb960a-2225-4720-950e-54ac6279614a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function timeSlot. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timeSlot(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1304, line 1307) (in query: SELECT timeSlot(-1);) 2025.06.13 15:46:02.096291 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function timeSlot. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timeSlot(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:02.220835 [ 8431 ] {1896f0c3-6050-4423-9512-7e6d477c5f04} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 0, should be 1: In scope SELECT wkt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1586, line 1592) (in query: SELECT wkt();) 2025.06.13 15:46:02.253137 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 0, should be 1: In scope SELECT wkt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:02.255880 [ 5978 ] {9d60259b-b848-4527-8565-fcb7b73585df} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 1, should be 2 or 3: In scope SELECT timeSlots(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1305, line 1308) (in query: SELECT timeSlots(-1);) 2025.06.13 15:46:02.298641 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 1, should be 2 or 3: In scope SELECT timeSlots(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:02.413986 [ 8431 ] {62aaffd5-84ba-46c2-9bb1-364f741f87eb} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHash expect at least one argument: In scope SELECT wordShingleMinHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1587, line 1593) (in query: SELECT wordShingleMinHash();) 2025.06.13 15:46:02.426255 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHash expect at least one argument: In scope SELECT wordShingleMinHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:46:02.448084 [ 5978 ] {cc544ed4-55dd-4639-8e55-807b88ce029d} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 1, should be 0: In scope SELECT timeZone(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1306, line 1309) (in query: SELECT timeZone(-1);) 2025.06.13 15:46:02.474420 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 1, should be 0: In scope SELECT timeZone(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:02.495381 [ 8431 ] {c7756dfa-12c0-467a-a66f-21ef806f19e3} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashArg expect at least one argument: In scope SELECT wordShingleMinHashArg(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1588, line 1594) (in query: SELECT wordShingleMinHashArg();) 2025.06.13 15:46:02.600321 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashArg expect at least one argument: In scope SELECT wordShingleMinHashArg(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:46:02.607088 [ 5978 ] {58a6c7f4-6d56-4388-ab0d-42fef7d8e030} executeQuery: Code: 36. DB::Exception: Bad argument for function timezoneOf, should be DateTime or DateTime64: In scope SELECT timeZoneOf(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1307, line 1310) (in query: SELECT timeZoneOf(-1);) 2025.06.13 15:46:02.618492 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: Bad argument for function timezoneOf, should be DateTime or DateTime64: In scope SELECT timeZoneOf(-1). (BAD_ARGUMENTS) 2025.06.13 15:46:02.655992 [ 8431 ] {a504a0a5-ddc6-4441-9e81-53832da5c8c4} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashArgCaseInsensitive expect at least one argument: In scope SELECT wordShingleMinHashArgCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1589, line 1595) (in query: SELECT wordShingleMinHashArgCaseInsensitive();) 2025.06.13 15:46:02.663116 [ 4107 ] {c04eb994-29e8-4a4b-a573-da2a7acec69f} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48946) (comment: 01497_alias_on_default_array.sql) (query 2, line 3) (in query: CREATE TABLE test_new_col (`_csv` String, `csv_as_array` Array(String) ALIAS splitByChar(';', _csv), `csv_col1` String DEFAULT csv_as_array[1], `csv_col2` String DEFAULT csv_as_array[2]) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 61001, min_bytes_for_wide_part = 32770920, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 404385774, compact_parts_max_granules_to_buffer = 25, compact_parts_merge_max_bytes_to_prefetch_part = 22150755, merge_max_block_size = 2287, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 3691330289, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 92, min_merge_bytes_to_use_direct_io = 5601123961, index_granularity_bytes = 23908169, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 48742, primary_key_compress_block_size = 36858, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:02.683155 [ 4107 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:02.685408 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashArgCaseInsensitive expect at least one argument: In scope SELECT wordShingleMinHashArgCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:46:02.734118 [ 5978 ] {9344dcfc-25b1-4d74-98ef-d5f096d136d6} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function timezoneOffset. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timeZoneOffset(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1308, line 1311) (in query: SELECT timeZoneOffset(-1);) 2025.06.13 15:46:02.756839 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function timezoneOffset. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timeZoneOffset(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:02.800991 [ 8431 ] {bcd7a57e-9707-45ca-9cc6-829c1411e55c} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashArgCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1590, line 1596) (in query: SELECT wordShingleMinHashArgCaseInsensitiveUTF8();) 2025.06.13 15:46:02.820709 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashArgCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:46:02.824223 [ 8101 ] {021fec21-9776-4c68-8aaf-4693fda93ecc} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 252, line 252) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addWeeks(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:02.834976 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:02.961602 [ 5978 ] {4d4e4994-74f3-4cde-82a6-1cb190ad4083} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 1, must be 2, 3 or 4: In scope SELECT time_bucket(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1309, line 1312) (in query: SELECT time_bucket(-1);) 2025.06.13 15:46:02.979099 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 1, must be 2, 3 or 4: In scope SELECT time_bucket(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:03.010308 [ 8431 ] {e7decd9c-c6eb-4165-aa1f-f20f7522e4e5} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashArgUTF8 expect at least one argument: In scope SELECT wordShingleMinHashArgUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1591, line 1597) (in query: SELECT wordShingleMinHashArgUTF8();) 2025.06.13 15:46:03.026765 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashArgUTF8 expect at least one argument: In scope SELECT wordShingleMinHashArgUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:46:03.099273 [ 5978 ] {6dc67f83-d54e-45e3-9516-45ffe36426c1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'timestamp' to function 'timestamp'. Expected: String or FixedString, got: Int8: In scope SELECT timestamp(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1310, line 1313) (in query: SELECT timestamp(-1);) 2025.06.13 15:46:03.104027 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'timestamp' to function 'timestamp'. Expected: String or FixedString, got: Int8: In scope SELECT timestamp(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:03.176231 [ 8431 ] {8650aa3e-93f9-444b-a83d-14074a37adc1} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashCaseInsensitive expect at least one argument: In scope SELECT wordShingleMinHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1592, line 1598) (in query: SELECT wordShingleMinHashCaseInsensitive();) 2025.06.13 15:46:03.191931 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashCaseInsensitive expect at least one argument: In scope SELECT wordShingleMinHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:46:03.301415 [ 5978 ] {ab252dd4-2cab-4603-97b7-9a5401cfbeeb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1311, line 1314) (in query: SELECT timestampDiff(-1);) 2025.06.13 15:46:03.308794 [ 18602 ] {0605082b-8a07-42ad-9eb3-888341a253ba} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02149_schema_inference_create_table_syntax.sh) (in query: /* ddl_entry=query-0000000006 */ TRUNCATE TABLE test_v8a2hay0.test_merge), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:46:03.324854 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:03.326788 [ 18511 ] {2eb0f665-ef07-449c-bfd2-eeac413428e2} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49028) (comment: 01264_nested_baloo_bear.sql) (query 2, line 3) (in query: CREATE TABLE LOG_T (`fingerprint` UInt64, `fields` Nested(name LowCardinality(String), value String)) ENGINE = MergeTree ORDER BY fingerprint SETTINGS index_granularity = 19789, min_bytes_for_wide_part = 0, 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 = 191144688, compact_parts_max_bytes_to_buffer = 235261161, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 10655032, merge_max_block_size = 7231, old_parts_lifetime = 223., prefer_fetch_merged_part_size_threshold = 7255969654, vertical_merge_algorithm_min_rows_to_activate = 300373, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5731373909, index_granularity_bytes = 15492370, 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 = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 70101, primary_key_compress_block_size = 85346, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:03.361618 [ 18602 ] {0605082b-8a07-42ad-9eb3-888341a253ba} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49048) (comment: 02149_schema_inference_create_table_syntax.sh) (query 1, line 1) (in query: drop table test_merge), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:46:03.362009 [ 18511 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:03.377693 [ 8431 ] {ebf6b123-e537-4aaa-b436-11856876e3fe} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleMinHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1593, line 1599) (in query: SELECT wordShingleMinHashCaseInsensitiveUTF8();) 2025.06.13 15:46:03.383964 [ 18602 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:46:03.420880 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleMinHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:46:03.449862 [ 5978 ] {cc55a470-4a4c-4621-90d5-bc6550c7ba5c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1312, line 1315) (in query: SELECT timestamp_diff(-1);) 2025.06.13 15:46:03.464187 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT dateDiff(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:03.643019 [ 8431 ] {943f4ddf-1946-4bdc-b5df-5c9e079ea8f7} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashUTF8 expect at least one argument: In scope SELECT wordShingleMinHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1594, line 1600) (in query: SELECT wordShingleMinHashUTF8();) 2025.06.13 15:46:03.648406 [ 5978 ] {6e5c092b-65b1-4f6f-b806-b7a97fed1db7} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 1, should be 0: In scope SELECT timezone(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1313, line 1316) (in query: SELECT timezone(-1);) 2025.06.13 15:46:03.651145 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashUTF8 expect at least one argument: In scope SELECT wordShingleMinHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:46:03.653338 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 1, should be 0: In scope SELECT timezone(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:03.817751 [ 5978 ] {fff36a2b-3e5d-49f7-a480-b105819c6a0a} executeQuery: Code: 36. DB::Exception: Bad argument for function timezoneOf, should be DateTime or DateTime64: In scope SELECT timezoneOf(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1314, line 1317) (in query: SELECT timezoneOf(-1);) 2025.06.13 15:46:03.832845 [ 8431 ] {137bbd9e-310b-46a4-ad14-56096613d2ad} executeQuery: Code: 35. DB::Exception: Function wordShingleSimHash expect at least one argument: In scope SELECT wordShingleSimHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1595, line 1601) (in query: SELECT wordShingleSimHash();) 2025.06.13 15:46:03.877094 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: Bad argument for function timezoneOf, should be DateTime or DateTime64: In scope SELECT timezoneOf(-1). (BAD_ARGUMENTS) 2025.06.13 15:46:03.910645 [ 8101 ] {7cc038f2-7d40-4f71-8898-877b835a78ac} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 257, line 257) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addDays(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:03.917309 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function wordShingleSimHash expect at least one argument: In scope SELECT wordShingleSimHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:46:03.923864 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:03.932863 [ 5978 ] {e273c8f9-e219-4e5f-bc70-9a809eb399ca} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function timezoneOffset. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timezoneOffset(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1315, line 1318) (in query: SELECT timezoneOffset(-1);) 2025.06.13 15:46:03.963230 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function timezoneOffset. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timezoneOffset(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:03.972940 [ 8431 ] {45fba753-cdd4-49ba-b3a1-cce5a1634eb9} executeQuery: Code: 35. DB::Exception: Function wordShingleSimHashCaseInsensitive expect at least one argument: In scope SELECT wordShingleSimHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1596, line 1602) (in query: SELECT wordShingleSimHashCaseInsensitive();) 2025.06.13 15:46:04.069028 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function wordShingleSimHashCaseInsensitive expect at least one argument: In scope SELECT wordShingleSimHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:46:04.181339 [ 8431 ] {feabd746-0c9b-40a6-aaa1-c701099ef378} executeQuery: Code: 35. DB::Exception: Function wordShingleSimHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleSimHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1597, line 1603) (in query: SELECT wordShingleSimHashCaseInsensitiveUTF8();) 2025.06.13 15:46:04.192040 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function wordShingleSimHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleSimHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:46:04.281873 [ 8431 ] {233e6332-2b07-4153-8553-3a38fa9b3d21} executeQuery: Code: 35. DB::Exception: Function wordShingleSimHashUTF8 expect at least one argument: In scope SELECT wordShingleSimHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1598, line 1604) (in query: SELECT wordShingleSimHashUTF8();) 2025.06.13 15:46:04.286981 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Function wordShingleSimHashUTF8 expect at least one argument: In scope SELECT wordShingleSimHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:46:04.381808 [ 5978 ] {2c80a3b6-b5e9-476e-bf79-e3901613b342} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toBFloat16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toBFloat16OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1317, line 1320) (in query: SELECT toBFloat16OrNull(-1);) 2025.06.13 15:46:04.416602 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toBFloat16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toBFloat16OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:04.645734 [ 6234 ] {87263289-c3b8-409a-aa5a-f2170da19c37} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=22). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48326) (comment: 03241_orc_dictionary_encode.sql) (query 18, line 37) (in query: select c, count(1) from file(concat(currentDatabase(), '_03241_data2_without_dict.orc'), ORC, 'c String') group by c order by c;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181b22b 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:46:04.674410 [ 5978 ] {88761b59-f6c5-4e86-8bf4-81976aa05f6a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toBFloat16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toBFloat16OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1318, line 1321) (in query: SELECT toBFloat16OrZero(-1);) 2025.06.13 15:46:04.684199 [ 6234 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=22). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181b22b 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181b22b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:46:04.687751 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toBFloat16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toBFloat16OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:04.805999 [ 8431 ] {a7adaa93-951a-43ac-8ced-d1b364a338e1} executeQuery: Code: 35. DB::Exception: Number of arguments for function "xor" should be at least 2: passed 0: In scope SELECT xor(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1600, line 1606) (in query: SELECT xor();) 2025.06.13 15:46:04.812540 [ 8431 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "xor" should be at least 2: passed 0: In scope SELECT xor(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:46:05.077828 [ 8101 ] {461b6e91-ad6e-4b0a-a419-a061bd318679} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 262, line 262) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addHours(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:05.087632 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:05.463999 [ 18380 ] {47f6b802-39a4-444f-87f4-4e5adcb2eb3d} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57252) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (query 11, line 21) (in query: -- { echoOn } -- SELECT -- intHash64(0) % 2, -- intHash64(2) % 2 -- ┌─modulo(intHash64(0), 2)─┬─modulo(intHash64(2), 2)─┠-- │ 0 │ 1 │ -- └─────────────────────────┴─────────────────────────┘ create table dist_01756 as system.one engine=Distributed(test_cluster_two_shards, system, one, intHash64(dummy));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:05.477130 [ 18380 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:05.485993 [ 3894 ] {fe82446a-d66b-4263-a54b-b8bd674b1033} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57280) (comment: 02346_fulltext_index_search.sql) (query 6, line 13) (in query: CREATE TABLE tab (`k` UInt64, `s` String, INDEX af s TYPE full_text(2) GRANULARITY 1) ENGINE = MergeTree ORDER BY k SETTINGS index_granularity = 2, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 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 = 142498349, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 31831574, merge_max_block_size = 17498, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 7936151408, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 99747, primary_key_compress_block_size = 82583, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:05.508982 [ 3894 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:05.619521 [ 8431 ] {b5f490c2-0223-4690-8b21-005a9830661d} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 0, should be 2: In scope SELECT yandexConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1604, line 1610) (in query: SELECT yandexConsistentHash();) 2025.06.13 15:46:05.625226 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 0, should be 2: In scope SELECT yandexConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:05.829871 [ 5978 ] {55d8af6b-babe-4f41-91a8-0fdf1e328ef3} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toDate32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDate32OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1324, line 1327) (in query: SELECT toDate32OrNull(-1);) 2025.06.13 15:46:05.832289 [ 8431 ] {860ef199-51f1-4aad-ab77-b6d3b582598c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYearWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT yearweek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:54918) (comment: 00534_functions_bad_arguments2.sh) (query 1605, line 1611) (in query: SELECT yearweek();) 2025.06.13 15:46:05.838088 [ 8431 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYearWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT yearweek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:05.860035 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toDate32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDate32OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:06.010113 [ 5978 ] {807d3e98-350e-4e92-a24b-55295006f75f} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toDate32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDate32OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1325, line 1328) (in query: SELECT toDate32OrZero(-1);) 2025.06.13 15:46:06.034372 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toDate32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDate32OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:06.101960 [ 8101 ] {0b16ab68-75f0-4d73-99bc-362184626700} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 267, line 267) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addMinutes(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:06.117092 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:06.472999 [ 5978 ] {7951fb1d-fc79-4c33-95c9-0c640012496b} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toDateOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1327, line 1330) (in query: SELECT toDateOrNull(-1);) 2025.06.13 15:46:06.477684 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toDateOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:06.592024 [ 5978 ] {c37b90c8-7a10-476d-bf71-dbe358494b6f} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toDateOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1328, line 1331) (in query: SELECT toDateOrZero(-1);) 2025.06.13 15:46:06.596584 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toDateOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:07.142273 [ 8101 ] {21e45c26-a7ac-40d1-adfd-9f4856e375ae} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 272, line 272) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addSeconds(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:07.148818 [ 5978 ] {0e90b25b-fb44-4bd9-b305-8044c29df910} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDateTime64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1331, line 1334) (in query: SELECT toDateTime64(-1);) 2025.06.13 15:46:07.159876 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDateTime64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:07.160177 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:07.178176 [ 5163 ] {dd700b40-57ff-4342-82dc-fea1192fc212} executeQuery: Code: 57. DB::Exception: Directory for table data data/test_7/test/ already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57356) (comment: 00704_arrayCumSumLimited_arrayDifference.sql) (query 6, line 11) (in query: CREATE TABLE test(a Array(Int64), b Array(Float64), c Array(UInt64)) ENGINE=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:46:07.221705 [ 5163 ] {} TCPHandler: Code: 57. DB::Exception: Directory for table data data/test_7/test/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1868: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc80e40 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:46:07.285447 [ 5978 ] {a4582bd1-dfbe-4e0e-9290-e7352e14e320} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrDefault'. Expected 2 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT toDateTime64OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1332, line 1335) (in query: SELECT toDateTime64OrDefault(-1);) 2025.06.13 15:46:07.290871 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrDefault'. Expected 2 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT toDateTime64OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:07.361181 [ 5978 ] {ae976e5b-6a29-4537-a4bc-67f5a5f57085} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrNull'. Expected: String or FixedString, got: Int8: In scope SELECT toDateTime64OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1333, line 1336) (in query: SELECT toDateTime64OrNull(-1);) 2025.06.13 15:46:07.377406 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrNull'. Expected: String or FixedString, got: Int8: In scope SELECT toDateTime64OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:07.562122 [ 5978 ] {40ce8fcb-2c5b-40fc-a999-19fa32229b9c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrZero'. Expected: String or FixedString, got: Int8: In scope SELECT toDateTime64OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1334, line 1337) (in query: SELECT toDateTime64OrZero(-1);) 2025.06.13 15:46:07.571644 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrZero'. Expected: String or FixedString, got: Int8: In scope SELECT toDateTime64OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:07.913061 [ 5978 ] {71e2ae57-7e59-40e7-918f-404443c7bf5d} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toDateTimeOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateTimeOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1336, line 1339) (in query: SELECT toDateTimeOrNull(-1);) 2025.06.13 15:46:08.000590 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toDateTimeOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateTimeOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:08.072235 [ 8101 ] {4fea07ab-6f1e-4da1-ba0d-3f8a0ba7d6b1} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 277, line 277) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addQuarters(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:08.075451 [ 5978 ] {b901f473-518e-417d-bc01-70f4fc5435de} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toDateTimeOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateTimeOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1337, line 1340) (in query: SELECT toDateTimeOrZero(-1);) 2025.06.13 15:46:08.101297 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:08.112364 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toDateTimeOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateTimeOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:08.153076 [ 9636 ] {0a96d038-1ac7-4ea2-8e94-145bb4a11df1} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57478) (comment: 00612_pk_in_tuple.sql) (query 2, line 2) (in query: CREATE TABLE tab_00612 (`key` UInt64, `arr` Array(UInt64)) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 29304, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 39, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 48337327, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 12944664, merge_max_block_size = 9326, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 50, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 11410045, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 99477, primary_key_compress_block_size = 97085, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:08.165502 [ 9636 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:08.182325 [ 8442 ] {15b7df66-6347-4aff-bc47-68e4fb48f49a} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57456) (comment: 00718_format_datetime.sql) (query 2, line 3) (in query: SELECT formatDateTime();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccaf6f 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad9829c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:46:08.191219 [ 8442 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000017ccaf6f 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad9829c 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:46:08.196805 [ 5978 ] {70e03552-54f5-4d4d-81a2-16d280397148} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfMonth(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1338, line 1341) (in query: SELECT toDayOfMonth(-1);) 2025.06.13 15:46:08.204585 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfMonth(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:08.312390 [ 5978 ] {3173e842-2c93-46a3-8656-e54860fcee0a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toDayOfWeek(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1339, line 1342) (in query: SELECT toDayOfWeek(-1);) 2025.06.13 15:46:08.325208 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toDayOfWeek(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:08.424856 [ 5978 ] {665c77a7-71c9-4242-b003-f2c6ff53c49b} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDayOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfYear(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1340, line 1343) (in query: SELECT toDayOfYear(-1);) 2025.06.13 15:46:08.464680 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDayOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfYear(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:08.542296 [ 5978 ] {7f965ce7-b2eb-49bb-b394-01ced0649943} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDaysSinceYearZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1341, line 1344) (in query: SELECT toDaysSinceYearZero(-1);) 2025.06.13 15:46:08.547061 [ 8442 ] {ebedf2c0-9d9a-4e99-ac87-0086eebdc803} executeQuery: Code: 43. DB::Exception: Illegal type String of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT formatDateTime('not a datetime', 'IGNORED'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57456) (comment: 00718_format_datetime.sql) (query 3, line 4) (in query: SELECT formatDateTime('not a datetime', 'IGNORED');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad98707 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:46:08.563955 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDaysSinceYearZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:08.569593 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT formatDateTime('not a datetime', 'IGNORED'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad98707 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:46:08.773904 [ 5978 ] {e961104f-4580-49fa-8290-95caa9f56821} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal128(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1342, line 1345) (in query: SELECT toDecimal128(-1);) 2025.06.13 15:46:08.792882 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal128(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:08.881216 [ 8101 ] {03d515a4-597d-4eff-b94e-eb8d1bd37930} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 282, line 282) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractYears(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:08.887107 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:08.892052 [ 8442 ] {035ba726-eb31-4097-9d97-913d03de25d2} executeQuery: Code: 43. DB::Exception: Illegal type DateTime of second argument of function formatDateTime. Must be String.: In scope SELECT formatDateTime(now(), now()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57456) (comment: 00718_format_datetime.sql) (query 4, line 5) (in query: SELECT formatDateTime(now(), now());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad9842e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:46:08.898376 [ 5978 ] {531c9ce5-7a7d-4ed1-8d3f-4f4048aaf440} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal128OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1343, line 1346) (in query: SELECT toDecimal128OrDefault(-1);) 2025.06.13 15:46:08.910176 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime of second argument of function formatDateTime. Must be String.: In scope SELECT formatDateTime(now(), now()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad9842e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:46:08.910826 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal128OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:09.079873 [ 5978 ] {d5d863c5-09f0-4c30-a4e3-09a9873bfe02} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1344, line 1347) (in query: SELECT toDecimal128OrNull(-1);) 2025.06.13 15:46:09.089014 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:09.201071 [ 5978 ] {e2697b01-e07d-4ae1-af53-87cf833e829e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1345, line 1348) (in query: SELECT toDecimal128OrZero(-1);) 2025.06.13 15:46:09.209308 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:09.244430 [ 9636 ] {5eee4ba5-687c-4fdb-abd8-6ef0dafc3235} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57542) (comment: 01655_plan_optimizations_merge_filters.sql) (query 4, line 6) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:09.257571 [ 9636 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:09.328861 [ 8442 ] {923d5677-6eec-4772-ac8e-50bd28892593} executeQuery: Code: 43. DB::Exception: Illegal type DateTime of third argument of function formatDateTime. Must be String.: In scope SELECT formatDateTime(now(), 'good format pattern', now()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57456) (comment: 00718_format_datetime.sql) (query 5, line 6) (in query: SELECT formatDateTime(now(), 'good format pattern', now());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad985a4 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:46:09.335373 [ 8432 ] {4a8a5a6d-4ffa-49b0-acbb-8a064ad4e041} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT IPv4StringToNum('test'). (CANNOT_PARSE_IPV4) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57552) (comment: 02234_cast_to_ip_address.sql) (query 2, line 3) (in query: SELECT IPv4StringToNum('test');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000017e2a471 6. DB::FunctionIPv4StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017e28446 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:46:09.341007 [ 8432 ] {} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT IPv4StringToNum('test'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000017e2a471 6. DB::FunctionIPv4StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017e28446 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:46:09.347565 [ 8442 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime of third argument of function formatDateTime. Must be String.: In scope SELECT formatDateTime(now(), 'good format pattern', now()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ad985a4 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:46:09.391350 [ 5978 ] {6d1fe8cc-4345-4c15-b8eb-e12e5f732e2d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal256(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1346, line 1349) (in query: SELECT toDecimal256(-1);) 2025.06.13 15:46:09.427596 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal256(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:09.512143 [ 5978 ] {3cb5c3cc-3677-4734-8919-561b886efa5d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal256OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1347, line 1350) (in query: SELECT toDecimal256OrDefault(-1);) 2025.06.13 15:46:09.517056 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal256OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:09.612079 [ 5978 ] {bc6b8d6a-06d3-4f32-85ed-4872ddbd0f6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1348, line 1351) (in query: SELECT toDecimal256OrNull(-1);) 2025.06.13 15:46:09.628686 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:09.715990 [ 8442 ] {d66f7db2-c58e-41e0-bb17-cea3f27c66c9} executeQuery: Code: 36. DB::Exception: '%' must not be the last character in the format string, use '%%' instead: In scope SELECT formatDateTime(now(), 'unescaped %'). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57456) (comment: 00718_format_datetime.sql) (query 6, line 7) (in query: SELECT formatDateTime(now(), 'unescaped %');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::throwLastCharacterIsPercentException() @ 0x000000001ad98cce 6. ? @ 0x000000001ad98bbd 7. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad93bb9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:46:09.730572 [ 8442 ] {} TCPHandler: Code: 36. DB::Exception: '%' must not be the last character in the format string, use '%%' instead: In scope SELECT formatDateTime(now(), 'unescaped %'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::throwLastCharacterIsPercentException() @ 0x000000001ad98cce 6. ? @ 0x000000001ad98bbd 7. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad93bb9 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:46:09.817737 [ 8101 ] {ad3407f0-ffd9-4cf5-b485-40d8025a846d} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 287, line 287) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractMonths(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:09.817991 [ 5978 ] {cc46be4b-fc27-4d7b-8c74-11012497e28c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1349, line 1352) (in query: SELECT toDecimal256OrZero(-1);) 2025.06.13 15:46:09.828359 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:09.830422 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:09.903929 [ 8442 ] {48141296-60c5-493f-9687-bd97a25cefb5} executeQuery: Code: 48. DB::Exception: format is not supported for WEEK (Sun-Sat): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%U'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57456) (comment: 00718_format_datetime.sql) (query 7, line 8) (in query: SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%U');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada30d1 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad93c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:46:09.964041 [ 5978 ] {4b166aa0-61f2-4bfe-bd8d-dec590ea06f2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1350, line 1353) (in query: SELECT toDecimal32(-1);) 2025.06.13 15:46:09.966609 [ 8442 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for WEEK (Sun-Sat): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%U'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada30d1 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad93c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:46:09.970457 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal32(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:10.123032 [ 5978 ] {7b6e60f8-62ee-42ea-b873-0d370a07ca98} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal32OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1351, line 1354) (in query: SELECT toDecimal32OrDefault(-1);) 2025.06.13 15:46:10.162406 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal32OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:10.186969 [ 8442 ] {f205fedd-0b8e-4764-8296-6be070b983b2} executeQuery: Code: 48. DB::Exception: format is not supported for WEEK (Mon-Sun): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%v'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57456) (comment: 00718_format_datetime.sql) (query 8, line 9) (in query: SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%v');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada2f5d 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad93c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:46:10.205026 [ 8442 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for WEEK (Mon-Sun): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%v'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada2f5d 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad93c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:46:10.270677 [ 5978 ] {71cc3b8f-f1e1-4a7b-a50b-331a5b29ecfb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1352, line 1355) (in query: SELECT toDecimal32OrNull(-1);) 2025.06.13 15:46:10.279678 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:10.419555 [ 8442 ] {6c41a58c-0d4e-4f0c-becc-b36ad1df1784} executeQuery: Code: 48. DB::Exception: format is not supported for YEAR for week (Mon-Sun): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%x'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57456) (comment: 00718_format_datetime.sql) (query 9, line 10) (in query: SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%x');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada31c7 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad93c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:46:10.424452 [ 8442 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for YEAR for week (Mon-Sun): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%x'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada31c7 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad93c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:46:10.428611 [ 8430 ] {3c681fa5-b180-464e-8aef-0126ae20ed29} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02149_schema_inference_create_table_syntax.sh) (in query: /* ddl_entry=query-0000000010 */ TRUNCATE TABLE test_v8a2hay0.test_buffer), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:46:10.430454 [ 5978 ] {aa4b401f-5573-4827-8b50-90aa15f8086c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1353, line 1356) (in query: SELECT toDecimal32OrZero(-1);) 2025.06.13 15:46:10.449106 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:10.477807 [ 8430 ] {3c681fa5-b180-464e-8aef-0126ae20ed29} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57640) (comment: 02149_schema_inference_create_table_syntax.sh) (query 1, line 1) (in query: drop table test_buffer), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:46:10.488362 [ 8430 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:46:10.548217 [ 5978 ] {85fcf493-dbda-4ecc-9e95-2012b0cbe6fa} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1354, line 1357) (in query: SELECT toDecimal64(-1);) 2025.06.13 15:46:10.553705 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 1 argument: In scope SELECT toDecimal64(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:10.707967 [ 8442 ] {e31eec69-21a4-42bf-85cd-613ac8a034b7} executeQuery: Code: 48. DB::Exception: format is not supported for YEAR for week (Sun-Sat): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%X'). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57456) (comment: 00718_format_datetime.sql) (query 10, line 11) (in query: SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%X');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada3151 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad93c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:46:10.715204 [ 8442 ] {} TCPHandler: Code: 48. DB::Exception: format is not supported for YEAR for week (Sun-Sat): In scope SELECT formatDateTime(toDateTime('2018-01-02 22:33:44'), '%X'). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. unsigned long DB::(anonymous namespace)::FunctionFormatDateTimeImpl::parseMySQLFormat(String const&, std::vector::Instruction, std::allocator::Instruction>>&, unsigned int, bool, String&) const @ 0x000000001ada3151 6. DB::(anonymous namespace)::FunctionFormatDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad93c1d 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 29. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 30. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 2025.06.13 15:46:10.740479 [ 5978 ] {6517c0a4-f99b-4fe5-a798-676a8b22e071} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal64OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1355, line 1358) (in query: SELECT toDecimal64OrDefault(-1);) 2025.06.13 15:46:10.761388 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT toDecimal64OrDefault(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:10.809475 [ 8101 ] {0737e7d3-f10d-49ee-8e90-8083eb3bbfac} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 292, line 292) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractWeeks(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:10.827369 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:10.880793 [ 5978 ] {32a52433-0289-4edd-8366-8d1dd65d05ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1356, line 1359) (in query: SELECT toDecimal64OrNull(-1);) 2025.06.13 15:46:10.891221 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:10.991446 [ 8432 ] {6c4ff4c8-f1c0-4528-91fd-362759cb92d7} executeQuery: Code: 675. DB::Exception: Cannot parse IPv4 test: Cannot parse IPv4 from String: In scope SELECT toIPv4('test'). (CANNOT_PARSE_IPV4) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57552) (comment: 02234_cast_to_ip_address.sql) (query 9, line 13) (in query: SELECT toIPv4('test');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x0000000017e3cd4f 5. ./src/IO/ReadHelpers.h:971: void DB::detail::parseImpl(DB::DataTypeIPv4::FieldType&, DB::ReadBuffer&, DateLUTImpl const*, bool) @ 0x000000002b1f7cd5 6. ./src/Functions/FunctionsConversion.h:1036: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b1f619d 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1f04c8 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02e18e 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b060d4a 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05fa83 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:46:11.000916 [ 8432 ] {} TCPHandler: Code: 675. DB::Exception: Cannot parse IPv4 test: Cannot parse IPv4 from String: In scope SELECT toIPv4('test'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x0000000017e3cd4f 5. ./src/IO/ReadHelpers.h:971: void DB::detail::parseImpl(DB::DataTypeIPv4::FieldType&, DB::ReadBuffer&, DateLUTImpl const*, bool) @ 0x000000002b1f7cd5 6. ./src/Functions/FunctionsConversion.h:1036: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b1f619d 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1f04c8 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02e18e 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b060d4a 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05fa83 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:46:11.316989 [ 5978 ] {bbb29d81-7d07-4073-8251-a776fc2bdcd6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1357, line 1360) (in query: SELECT toDecimal64OrZero(-1);) 2025.06.13 15:46:11.325486 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 1, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:11.454448 [ 5978 ] {c35829c5-1027-4588-8820-df7ebc718820} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 1, should be 2: In scope SELECT toDecimalString(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1358, line 1361) (in query: SELECT toDecimalString(-1);) 2025.06.13 15:46:11.467091 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 1, should be 2: In scope SELECT toDecimalString(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:11.582599 [ 5978 ] {e8603bfe-0ce5-4343-a4c7-e441218c0a0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 1, should be 2: In scope SELECT toFixedString(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1359, line 1362) (in query: SELECT toFixedString(-1);) 2025.06.13 15:46:11.599783 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 1, should be 2: In scope SELECT toFixedString(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:11.964998 [ 8101 ] {f04f265b-293d-439d-8165-52dc64d41219} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 297, line 297) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractDays(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:11.978690 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:12.076643 [ 5978 ] {e50324b2-d313-446c-8082-5d47075c6ea0} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toFloat32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat32OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1362, line 1365) (in query: SELECT toFloat32OrNull(-1);) 2025.06.13 15:46:12.083420 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toFloat32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat32OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:12.184683 [ 5978 ] {27dcfc6f-0268-4dde-9a9c-0e957749e3d1} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toFloat32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat32OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1363, line 1366) (in query: SELECT toFloat32OrZero(-1);) 2025.06.13 15:46:12.196021 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toFloat32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat32OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:12.810622 [ 8432 ] {c9e92c43-925a-467f-b32e-73be0a610a70} executeQuery: Code: 70. DB::Exception: IPv6 ::afff:102:304 in column IPv6 is not in IPv4 mapping block: In scope SELECT toIPv4(toIPv6('::afff:1.2.3.4')). (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57552) (comment: 02234_cast_to_ip_address.sql) (query 17, line 24) (in query: SELECT toIPv4(toIPv6('::afff:1.2.3.4'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char (&) [46], String&&) @ 0x000000002add77af 5. ./src/Functions/FunctionsConversion.h:1779: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b1faf3f 6. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1f09c6 7. ./src/Core/callOnTypeIndex.h:288: 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&&) @ 0x000000002b02e297 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b060d4a 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05fa83 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:46:12.845019 [ 8432 ] {} TCPHandler: Code: 70. DB::Exception: IPv6 ::afff:102:304 in column IPv6 is not in IPv4 mapping block: In scope SELECT toIPv4(toIPv6('::afff:1.2.3.4')). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char (&) [46], String&&) @ 0x000000002add77af 5. ./src/Functions/FunctionsConversion.h:1779: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b1faf3f 6. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1f09c6 7. ./src/Core/callOnTypeIndex.h:288: 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&&) @ 0x000000002b02e297 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b060d4a 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b05fa83 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:46:12.864504 [ 5978 ] {e7c260e1-d42f-40f4-b3c7-460c5774cc2d} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toFloat64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat64OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1366, line 1369) (in query: SELECT toFloat64OrNull(-1);) 2025.06.13 15:46:12.869093 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toFloat64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat64OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:12.890405 [ 8101 ] {3bb757e3-9ee3-40f0-876f-7627d0bc23c0} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 302, line 302) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractHours(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:12.897585 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:12.925208 [ 8099 ] {533f13fa-867a-4c7e-9790-1380da502a1c} executeQuery: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t1.x. (NOT_AN_AGGREGATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57742) (comment: 03130_analyzer_self_join_group_by.sql) (query 5, line 7) (in query: SELECT t2.x FROM t1 JOIN t1 as t2 ON t1.x = t2.x GROUP BY t1.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:12.930246 [ 8099 ] {} TCPHandler: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t1.x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:12.980219 [ 5978 ] {9ac821ad-04e1-495f-870e-a6c4e4e1606a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toFloat64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat64OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1367, line 1370) (in query: SELECT toFloat64OrZero(-1);) 2025.06.13 15:46:12.991278 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toFloat64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat64OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:13.038482 [ 8099 ] {8a63d7df-c214-4886-917d-1152298be63f} executeQuery: Code: 215. DB::Exception: Column t2.number is not under aggregate function and not in GROUP BY keys. In query SELECT t2.number FROM numbers(10) AS t1 INNER JOIN numbers(10) AS t2 ON t1.number = t2.number GROUP BY t1.number. (NOT_AN_AGGREGATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57742) (comment: 03130_analyzer_self_join_group_by.sql) (query 6, line 8) (in query: SELECT t2.number FROM numbers(10) as t1 JOIN numbers(10) as t2 ON t1.number = t2.number GROUP BY t1.number;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:13.046120 [ 8099 ] {} TCPHandler: Code: 215. DB::Exception: Column t2.number is not under aggregate function and not in GROUP BY keys. In query SELECT t2.number FROM numbers(10) AS t1 INNER JOIN numbers(10) AS t2 ON t1.number = t2.number GROUP BY t1.number. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:13.221764 [ 5978 ] {07fbdef4-df00-4e66-aa71-1ed798d4082d} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toHour(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1368, line 1371) (in query: SELECT toHour(-1);) 2025.06.13 15:46:13.230038 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toHour(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:13.248286 [ 8099 ] {dcc8bf33-15b2-4b35-8084-e2bb890d58a9} executeQuery: Code: 215. DB::Exception: Column t2.a is not under aggregate function and not in GROUP BY keys. In query SELECT t2.a FROM (SELECT x AS a FROM t1) AS t1 INNER JOIN (SELECT x AS a FROM t1) AS t2 ON t1.a = t2.a GROUP BY t1.a. (NOT_AN_AGGREGATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57742) (comment: 03130_analyzer_self_join_group_by.sql) (query 7, line 9) (in query: SELECT t2.a FROM (SELECT x as a FROM t1) as t1 JOIN (SELECT x as a FROM t1) as t2 ON t1.a = t2.a GROUP BY t1.a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:13.254586 [ 8099 ] {} TCPHandler: Code: 215. DB::Exception: Column t2.a is not under aggregate function and not in GROUP BY keys. In query SELECT t2.a FROM (SELECT x AS a FROM t1) AS t1 INNER JOIN (SELECT x AS a FROM t1) AS t2 ON t1.a = t2.a GROUP BY t1.a. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:13.292062 [ 18511 ] {af63a928-02ee-49a4-8e62-9e7cc28e886e} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57922) (comment: 02473_functions_in_readonly_mode.sh) (query 1, line 1) (in query: SELECT * from format('TSV', '123')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4a216 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd49055 6. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x000000002bd176fd 7. ./src/Access/ContextAccess.h:254: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002d4ba767 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:31: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dbd60 9. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:46:13.315857 [ 18511 ] {} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4a216 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd49055 6. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x000000002bd176fd 7. ./src/Access/ContextAccess.h:254: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002d4ba767 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:31: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dbd60 9. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:46:13.446046 [ 5978 ] {0ef05812-f469-42bd-bec1-333e80d53c06} executeQuery: Code: 48. DB::Exception: Conversion from Int8 to IPv4 is not supported: In scope SELECT toIPv4(-1). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1369, line 1372) (in query: SELECT toIPv4(-1);) 2025.06.13 15:46:13.462002 [ 5978 ] {} TCPHandler: Code: 48. DB::Exception: Conversion from Int8 to IPv4 is not supported: In scope SELECT toIPv4(-1). (NOT_IMPLEMENTED) 2025.06.13 15:46:13.475442 [ 8099 ] {813dd519-a404-4192-b8e4-4ff81d899805} executeQuery: Code: 215. DB::Exception: Column t2.a is not under aggregate function and not in GROUP BY keys. In query SELECT t2.a FROM (SELECT x AS a FROM t1 UNION ALL SELECT x AS a FROM t1) AS t1 INNER JOIN (SELECT x AS a FROM t1 UNION ALL SELECT x AS a FROM t1) AS t2 ON t1.a = t2.a GROUP BY t1.a. (NOT_AN_AGGREGATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57742) (comment: 03130_analyzer_self_join_group_by.sql) (query 8, line 10) (in query: SELECT t2.a FROM (SELECT x as a FROM t1 UNION ALL SELECT x as a FROM t1) as t1 JOIN (SELECT x as a FROM t1 UNION ALL SELECT x as a FROM t1) as t2 ON t1.a = t2.a GROUP BY t1.a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:13.487422 [ 8099 ] {} TCPHandler: Code: 215. DB::Exception: Column t2.a is not under aggregate function and not in GROUP BY keys. In query SELECT t2.a FROM (SELECT x AS a FROM t1 UNION ALL SELECT x AS a FROM t1) AS t1 INNER JOIN (SELECT x AS a FROM t1 UNION ALL SELECT x AS a FROM t1) AS t2 ON t1.a = t2.a GROUP BY t1.a. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:13.601806 [ 8099 ] {1f92d4bb-5659-4a23-a690-f84a3b2829c0} executeQuery: Code: 215. DB::Exception: Column t2.number is not under aggregate function and not in GROUP BY keys. In query SELECT t2.number FROM numbers(10) INNER JOIN numbers(10) AS t2 ON number = t2.number GROUP BY number SETTINGS joined_subquery_requires_alias = 0. (NOT_AN_AGGREGATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57742) (comment: 03130_analyzer_self_join_group_by.sql) (query 9, line 11) (in query: SELECT t2.number FROM numbers(10) JOIN numbers(10) as t2 ON number = t2.number GROUP BY number SETTINGS joined_subquery_requires_alias = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:13.621021 [ 8099 ] {} TCPHandler: Code: 215. DB::Exception: Column t2.number is not under aggregate function and not in GROUP BY keys. In query SELECT t2.number FROM numbers(10) INNER JOIN numbers(10) AS t2 ON number = t2.number GROUP BY number SETTINGS joined_subquery_requires_alias = 0. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:13.759890 [ 8099 ] {1f5f50fb-8156-49b9-bd1d-f8e26f355f0c} executeQuery: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 AS t0 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t1.x. (NOT_AN_AGGREGATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57742) (comment: 03130_analyzer_self_join_group_by.sql) (query 10, line 13) (in query: SELECT t2.x FROM t1 as t0 JOIN t1 as t2 ON t1.x = t2.x GROUP BY t1.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:13.771670 [ 8099 ] {} TCPHandler: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 AS t0 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t1.x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:13.781750 [ 8101 ] {6c4306b1-d905-498f-a0ea-c4337d10d9de} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 307, line 307) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractMinutes(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:13.792472 [ 5978 ] {1cec0437-21e8-4683-8dcf-610f65e81010} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toIPv4OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv4OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1371, line 1374) (in query: SELECT toIPv4OrNull(-1);) 2025.06.13 15:46:13.816379 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toIPv4OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv4OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:13.853316 [ 8099 ] {38763e88-ce0a-42e7-a3e5-57eccca8f41e} executeQuery: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 AS t0 INNER JOIN t1 AS t2 ON t0.x = t2.x GROUP BY t0.x. (NOT_AN_AGGREGATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57742) (comment: 03130_analyzer_self_join_group_by.sql) (query 11, line 14) (in query: SELECT t2.x FROM t1 as t0 JOIN t1 as t2 ON t0.x = t2.x GROUP BY t0.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:13.881446 [ 8432 ] {fa1b4a4d-9a2a-440e-8c42-176affc890d3} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT CAST('test', 'IPv4'). (CANNOT_PARSE_IPV4) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57552) (comment: 02234_cast_to_ip_address.sql) (query 21, line 30) (in query: SELECT cast('test' , 'IPv4');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000002adbf551 6. bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002adbdad9 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adbd8a2 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:46:13.882444 [ 8099 ] {} TCPHandler: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 AS t0 INNER JOIN t1 AS t2 ON t0.x = t2.x GROUP BY t0.x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:13.883904 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:13.902909 [ 8432 ] {} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT CAST('test', 'IPv4'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000002adbf551 6. bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002adbdad9 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adbd8a2 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:46:13.920095 [ 5978 ] {0e0a813b-4d11-4b4c-86c0-459847958175} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toIPv4OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv4OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1372, line 1375) (in query: SELECT toIPv4OrZero(-1);) 2025.06.13 15:46:13.928644 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toIPv4OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv4OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:14.003071 [ 4172 ] {bf677b48-7ca8-4b7c-938d-7551d70f1057} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55936) (comment: 02473_functions_in_readonly_mode.sh) (query 1, line 1) (in query: INSERT INTO FUNCTION null('x String') (x) FORMAT TSV ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4a216 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd49055 6. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x000000002bd176fd 7. ./src/Access/ContextAccess.h:254: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002d4ba767 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:31: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dbd60 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:153: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd96e0 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:14.053938 [ 4172 ] {} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4a216 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x000000002bd49055 6. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x000000002bd176fd 7. ./src/Access/ContextAccess.h:254: void DB::Context::checkAccessImpl(DB::AccessFlags const&) const @ 0x000000002d4ba767 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:31: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dbd60 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:153: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd96e0 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:14.071831 [ 8099 ] {f2c09b5e-38f4-4319-b9b8-464fb982289f} executeQuery: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY x. (NOT_AN_AGGREGATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57742) (comment: 03130_analyzer_self_join_group_by.sql) (query 12, line 15) (in query: SELECT t2.x FROM t1 JOIN t1 as t2 ON t1.x = t2.x GROUP BY x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:14.078755 [ 8099 ] {} TCPHandler: Code: 215. DB::Exception: Column t2.x is not under aggregate function and not in GROUP BY keys. In query SELECT t2.x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:14.115267 [ 5978 ] {853fcee2-01e2-4d67-8e7d-0e53590a8318} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and IPv6 is not supported. Probably the passed IPv6 is unquoted: In scope SELECT toIPv6(-1). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1373, line 1376) (in query: SELECT toIPv6(-1);) 2025.06.13 15:46:14.127235 [ 5978 ] {} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and IPv6 is not supported. Probably the passed IPv6 is unquoted: In scope SELECT toIPv6(-1). (NOT_IMPLEMENTED) 2025.06.13 15:46:14.350922 [ 8099 ] {5955db87-045b-48ed-9521-35cd2c9f7214} executeQuery: Code: 215. DB::Exception: Column test_44e4rur8.t1.x is not under aggregate function and not in GROUP BY keys. In query SELECT t1.x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t2.x. (NOT_AN_AGGREGATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57742) (comment: 03130_analyzer_self_join_group_by.sql) (query 13, line 16) (in query: SELECT t1.x FROM t1 JOIN t1 as t2 ON t1.x = t2.x GROUP BY t2.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:14.361938 [ 8099 ] {} TCPHandler: Code: 215. DB::Exception: Column test_44e4rur8.t1.x is not under aggregate function and not in GROUP BY keys. In query SELECT t1.x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t2.x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:14.653618 [ 5978 ] {608f0a34-b620-47b9-b4f7-f5eb3f84f544} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toIPv6OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv6OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1375, line 1378) (in query: SELECT toIPv6OrNull(-1);) 2025.06.13 15:46:14.660652 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toIPv6OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv6OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:14.660892 [ 8099 ] {5973285c-9299-4cff-9038-c90364a89219} executeQuery: Code: 215. DB::Exception: Column test_44e4rur8.t1.x is not under aggregate function and not in GROUP BY keys. In query SELECT x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t2.x. (NOT_AN_AGGREGATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57742) (comment: 03130_analyzer_self_join_group_by.sql) (query 14, line 17) (in query: SELECT x FROM t1 JOIN t1 as t2 ON t1.x = t2.x GROUP BY t2.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:14.677766 [ 8099 ] {} TCPHandler: Code: 215. DB::Exception: Column test_44e4rur8.t1.x is not under aggregate function and not in GROUP BY keys. In query SELECT x FROM t1 INNER JOIN t1 AS t2 ON t1.x = t2.x GROUP BY t2.x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:14.740880 [ 5978 ] {f265bbe9-f40f-49e7-9a19-441de3152a0f} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toIPv6OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv6OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1376, line 1379) (in query: SELECT toIPv6OrZero(-1);) 2025.06.13 15:46:14.747201 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toIPv6OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv6OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:14.839982 [ 5978 ] {6c411b75-fd9d-42d8-917d-4e4852cc056d} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toISOWeek. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toISOWeek(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1377, line 1380) (in query: SELECT toISOWeek(-1);) 2025.06.13 15:46:14.862888 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toISOWeek. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toISOWeek(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:14.891131 [ 8099 ] {7d8eeeca-8b16-4130-bcc1-c9db0c20c2d3} executeQuery: Code: 215. DB::Exception: Column test_44e4rur8.t1.x is not under aggregate function and not in GROUP BY keys. In query SELECT x FROM t1 INNER JOIN t1 AS t2 USING (x) GROUP BY t2.x. (NOT_AN_AGGREGATE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57742) (comment: 03130_analyzer_self_join_group_by.sql) (query 15, line 18) (in query: SELECT x FROM t1 JOIN t1 as t2 USING (x) GROUP BY t2.x;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:14.897363 [ 8099 ] {} TCPHandler: Code: 215. DB::Exception: Column test_44e4rur8.t1.x is not under aggregate function and not in GROUP BY keys. In query SELECT x FROM t1 INNER JOIN t1 AS t2 USING (x) GROUP BY t2.x. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:46:15.010886 [ 5978 ] {93cf5a99-c4c8-4434-9bf5-c9ac8ee3a054} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toISOYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toISOYear(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1378, line 1381) (in query: SELECT toISOYear(-1);) 2025.06.13 15:46:15.025143 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toISOYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toISOYear(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:15.071976 [ 8101 ] {304121e3-e7f6-488c-bd22-f812838124f7} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 312, line 312) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractSeconds(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:15.114827 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:15.488574 [ 5978 ] {263454c3-3c74-4051-b120-826cc9729c7d} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt128OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt128OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1381, line 1384) (in query: SELECT toInt128OrNull(-1);) 2025.06.13 15:46:15.527429 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt128OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt128OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:15.663700 [ 5978 ] {2c0268ad-d552-44f7-aab8-4d3697bd2f75} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt128OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt128OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1382, line 1385) (in query: SELECT toInt128OrZero(-1);) 2025.06.13 15:46:15.676713 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt128OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt128OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:16.139175 [ 8101 ] {2b0f8a1b-9276-4347-837d-a010bc6ea664} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 317, line 317) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractQuarters(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.06.13 15:46:16.237156 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:16.323620 [ 5978 ] {b2919a98-3046-4742-accb-b5cf36d7b75e} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt16OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1385, line 1388) (in query: SELECT toInt16OrNull(-1);) 2025.06.13 15:46:16.368483 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt16OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:16.541203 [ 5978 ] {a81c95fd-6010-42cb-89cf-ff6c3e3b1399} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt16OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1386, line 1389) (in query: SELECT toInt16OrZero(-1);) 2025.06.13 15:46:16.551507 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt16OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:16.593135 [ 8432 ] {0b954954-24bb-49af-a7de-80df6e7ecb44} executeQuery: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT IPv6StringToNum('test'). (CANNOT_PARSE_IPV6) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57552) (comment: 02234_cast_to_ip_address.sql) (query 33, line 48) (in query: SELECT IPv6StringToNum('test');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000017e34cb1 6. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000017e3280a 7. DB::FunctionIPv6StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017e31b86 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:46:16.610536 [ 8432 ] {} TCPHandler: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT IPv6StringToNum('test'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000017e34cb1 6. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000017e3280a 7. DB::FunctionIPv6StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017e31b86 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:46:17.172064 [ 5978 ] {d3f1cf0b-7ac4-40db-9c1b-0b5e4d961459} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt256OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt256OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1389, line 1392) (in query: SELECT toInt256OrNull(-1);) 2025.06.13 15:46:17.225038 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt256OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt256OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:17.241724 [ 5110 ] {b5761523-eabf-4a9b-bb3c-19c7d14a249a} executeQuery: Code: 469. DB::Exception: Constraint `bogus` for table _temporary_and_external_tables.`_tmp_9d61a212-8e49-4245-93e2-cf87750ecf09` (9d61a212-8e49-4245-93e2-cf87750ecf09) is violated at row 1. Expression: (0). Column values: . (VIOLATED_CONSTRAINT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56114) (comment: 01358_constexpr_constraint.sql) (query 5, line 12) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5e9077 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031da1148 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:46:17.269285 [ 4107 ] {sleep_query_id_02932_kill_query_sleep_test_15_16364} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56130) (comment: 02932_kill_query_sleep.sh) (query 1, line 1) (in query: SELECT sleep(1000)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002dee820f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002dee8126 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee88f7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:46:17.270837 [ 5110 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `bogus` for table _temporary_and_external_tables.`_tmp_9d61a212-8e49-4245-93e2-cf87750ecf09` (9d61a212-8e49-4245-93e2-cf87750ecf09) is violated at row 1. Expression: (0). Column values: . (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5e9077 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031da1148 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:46:17.282099 [ 4107 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x000000002dee820f 6. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x000000002dee8126 7. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee88f7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:46:17.301397 [ 5978 ] {5469e83d-cdf1-47b7-a29d-dc6ee97dd764} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt256OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt256OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1390, line 1393) (in query: SELECT toInt256OrZero(-1);) 2025.06.13 15:46:17.328375 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt256OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt256OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:17.688767 [ 18511 ] {31d69cd2-06c8-417c-aa07-b8bc535d7f8e} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_ww6mlyc5.rename1 (3cca5120-2f83-43ca-887e-56a11f3e0b59)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56056) (comment: 00620_optimize_on_nonleader_replica_zookeeper.sql) (query 6, line 12) (in query: INSERT INTO rename1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:46:17.699980 [ 18511 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_ww6mlyc5.rename1 (3cca5120-2f83-43ca-887e-56a11f3e0b59)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:46:17.943871 [ 18511 ] {73ad2e1a-3342-433d-8684-9770944cb2f8} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_ww6mlyc5.rename1 (3cca5120-2f83-43ca-887e-56a11f3e0b59)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60544) (comment: 00620_optimize_on_nonleader_replica_zookeeper.sql) (in query: DROP DATABASE IF EXISTS test_ww6mlyc5 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:46:17.953059 [ 18511 ] {73ad2e1a-3342-433d-8684-9770944cb2f8} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_ww6mlyc5.rename1 (3cca5120-2f83-43ca-887e-56a11f3e0b59)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:17.986848 [ 3704 ] {} virtual void DB::ServerAsynchronousMetrics::updateImpl(TimePoint, TimePoint, bool, bool, AsynchronousMetricValues &): Cannot get replica delay for table: test_ww6mlyc5.rename2: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ww6mlyc5/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000030587a41 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7516: DB::StorageReplicatedMergeTree::getReplicaDelays(long&, long&) @ 0x00000000306a9152 7. ./build_docker/./src/Interpreters/ServerAsynchronousMetrics.cpp:372: DB::ServerAsynchronousMetrics::updateImpl(std::chrono::time_point>>, std::chrono::time_point>>, bool, bool, std::unordered_map, std::equal_to, std::allocator>>&) @ 0x000000002df1e685 8. ./build_docker/./src/Common/AsynchronousMetrics.cpp:1833: DB::AsynchronousMetrics::update(std::chrono::time_point>>, bool) @ 0x0000000023c6ec99 9. ./build_docker/./src/Common/AsynchronousMetrics.cpp:390: DB::AsynchronousMetrics::run() @ 0x0000000023c713a6 10. ./build_docker/./src/Common/AsynchronousMetrics.cpp:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::AsynchronousMetrics::start()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000023c731de 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:18.083505 [ 5978 ] {2fe82fef-583d-4e22-897a-db31bc635f41} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt32OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1393, line 1396) (in query: SELECT toInt32OrNull(-1);) 2025.06.13 15:46:18.095600 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt32OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:18.272869 [ 5978 ] {e6deb007-a8dc-411c-bcc7-84a775e900c0} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt32OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1394, line 1397) (in query: SELECT toInt32OrZero(-1);) 2025.06.13 15:46:18.300496 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt32OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:18.491044 [ 8432 ] {0c8e0180-df3c-44a2-852f-a34ff64a3819} executeQuery: Code: 676. DB::Exception: Cannot parse IPv6 test: Cannot parse IPv6 from String: In scope SELECT toIPv6('test'). (CANNOT_PARSE_IPV6) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57552) (comment: 02234_cast_to_ip_address.sql) (query 40, line 58) (in query: SELECT toIPv6('test');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x0000000017e3cd4f 5. ./src/IO/ReadHelpers.h:993: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b202aa3 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1fcfc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02e48e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b06326a 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b061fa3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:46:18.520769 [ 8431 ] {b61c6ee4-6473-4921-a5c0-4a36e671dae3} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56264) (comment: 02843_backup_use_same_password_for_base_backup.sh) (query 4, line 5) (in query: CREATE TABLE data (`key` Int) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 44627, 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 = 167575455, compact_parts_max_bytes_to_buffer = 82167499, compact_parts_max_granules_to_buffer = 76, compact_parts_merge_max_bytes_to_prefetch_part = 33229510, merge_max_block_size = 1467, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 7467014353, 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 = 19194813, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 30075, primary_key_compress_block_size = 69265, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:18.533152 [ 8431 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:18.614475 [ 8432 ] {} TCPHandler: Code: 676. DB::Exception: Cannot parse IPv6 test: Cannot parse IPv6 from String: In scope SELECT toIPv6('test'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x0000000017e3cd4f 5. ./src/IO/ReadHelpers.h:993: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b202aa3 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1fcfc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02e48e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b06326a 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b061fa3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:46:18.827145 [ 5978 ] {56d8b851-6a2f-4bad-9ac8-d41436fc2456} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt64OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1397, line 1400) (in query: SELECT toInt64OrNull(-1);) 2025.06.13 15:46:18.839365 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt64OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:19.052944 [ 5978 ] {891a31df-9c68-4615-bed6-09ddebf011ff} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt64OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1398, line 1401) (in query: SELECT toInt64OrZero(-1);) 2025.06.13 15:46:19.060373 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt64OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:19.154621 [ 10735 ] {e3784bc5-c10f-4126-abc0-66d8d1c0893e} BackupsWorker: Failed to make backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_base.zip'): Code: 60. DB::Exception: Table test_5.data was not found. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:635: DB::BackupEntriesCollector::findTablesInDatabase(String const&) const @ 0x000000002bf084af 6. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:510: DB::BackupEntriesCollector::gatherTablesMetadata() @ 0x000000002befe338 7. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:264: DB::BackupEntriesCollector::tryGatherMetadataAndCompareWithPrevious(int, std::optional&, bool&) @ 0x000000002befaaf4 8. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:226: DB::BackupEntriesCollector::gatherMetadataAndCheckConsistency() @ 0x000000002bef5733 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:147: DB::BackupEntriesCollector::run() @ 0x000000002bef4192 10. ./build_docker/./src/Backups/BackupsWorker.cpp:582: 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&) @ 0x000000002bf3b856 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39173 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e6b 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:19.175562 [ 10735 ] {e3784bc5-c10f-4126-abc0-66d8d1c0893e} BackupImpl: An error happened, the backup won't be completed 2025.06.13 15:46:19.221363 [ 6193 ] {e3784bc5-c10f-4126-abc0-66d8d1c0893e} executeQuery: Code: 60. DB::Exception: Table test_5.data was not found. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56356) (comment: 02843_backup_use_same_password_for_base_backup.sh) (query 1, line 1) (in query: BACKUP TABLE data TO Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_base.zip') SETTINGS password='password';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:635: DB::BackupEntriesCollector::findTablesInDatabase(String const&) const @ 0x000000002bf084af 6. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:510: DB::BackupEntriesCollector::gatherTablesMetadata() @ 0x000000002befe338 7. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:264: DB::BackupEntriesCollector::tryGatherMetadataAndCompareWithPrevious(int, std::optional&, bool&) @ 0x000000002befaaf4 8. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:226: DB::BackupEntriesCollector::gatherMetadataAndCheckConsistency() @ 0x000000002bef5733 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:147: DB::BackupEntriesCollector::run() @ 0x000000002bef4192 10. ./build_docker/./src/Backups/BackupsWorker.cpp:582: 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&) @ 0x000000002bf3b856 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:19.244265 [ 6193 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.data was not found. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:635: DB::BackupEntriesCollector::findTablesInDatabase(String const&) const @ 0x000000002bf084af 6. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:510: DB::BackupEntriesCollector::gatherTablesMetadata() @ 0x000000002befe338 7. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:264: DB::BackupEntriesCollector::tryGatherMetadataAndCompareWithPrevious(int, std::optional&, bool&) @ 0x000000002befaaf4 8. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:226: DB::BackupEntriesCollector::gatherMetadataAndCheckConsistency() @ 0x000000002bef5733 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:147: DB::BackupEntriesCollector::run() @ 0x000000002bef4192 10. ./build_docker/./src/Backups/BackupsWorker.cpp:582: 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&) @ 0x000000002bf3b856 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39173 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e6b 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:19.634076 [ 5978 ] {bfb8f191-cc6f-4156-96f0-62d9ca001753} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt8OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1401, line 1404) (in query: SELECT toInt8OrNull(-1);) 2025.06.13 15:46:19.666019 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt8OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:19.688750 [ 7755 ] {262d9a8e-590f-4eea-b16b-33c133ae38a7} executeQuery: Code: 60. DB::Exception: Table test_5.data does not exist. Maybe you meant test_1.data?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56396) (comment: 02843_backup_use_same_password_for_base_backup.sh) (query 1, line 1) (in query: INSERT INTO data SELECT * FROM numbers(10,10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:19.693904 [ 7755 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.data does not exist. Maybe you meant test_1.data?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:19.754623 [ 5978 ] {de260f95-2f48-47ea-8304-d1a10f532809} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt8OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt8OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1402, line 1405) (in query: SELECT toInt8OrZero(-1);) 2025.06.13 15:46:19.763556 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toInt8OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt8OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:19.990671 [ 9636 ] {ed61823b-9823-42cc-a396-9f71095163db} executeQuery: Code: 47. DB::Exception: Missing columns: 'x' while processing: 'WITH 1 AS compound_value SELECT compound_value.*, compound_value.* FROM test_table WHERE x > 0 SETTINGS convert_query_to_cnf = true, optimize_using_constraints = true, optimize_substitute_columns = true', required columns: 'x': While processing WITH 1 AS compound_value SELECT compound_value.*, compound_value.* FROM test_table WHERE x > 0 SETTINGS convert_query_to_cnf = true, optimize_using_constraints = true, optimize_substitute_columns = true. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56386) (comment: 03212_optimize_with_constraints_logical_error.sql) (query 3, line 8) (in query: EXPLAIN SYNTAX WITH 1 AS compound_value SELECT * APPLY (x -> compound_value.*) FROM test_table WHERE x > 0 SETTINGS convert_query_to_cnf = true, optimize_using_constraints = true, optimize_substitute_columns = true;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000002e1a2e0c 5. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1448: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000002e1aaead 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: 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 @ 0x000000002dd0d328 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002dd069c5 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:488: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002dcfea26 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:305: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dcfe813 10. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002dcbca66 11. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002dcbd104 12. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002dcbd10f 13. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002dcbd10f 14. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x000000002dcb3564 15. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x000000002dcb0bec 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:46:20.001642 [ 9636 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'x' while processing: 'WITH 1 AS compound_value SELECT compound_value.*, compound_value.* FROM test_table WHERE x > 0 SETTINGS convert_query_to_cnf = true, optimize_using_constraints = true, optimize_substitute_columns = true', required columns: 'x': While processing WITH 1 AS compound_value SELECT compound_value.*, compound_value.* FROM test_table WHERE x > 0 SETTINGS convert_query_to_cnf = true, optimize_using_constraints = true, optimize_substitute_columns = true. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000002e1a2e0c 5. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1448: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x000000002e1aaead 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:761: 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 @ 0x000000002dd0d328 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:932: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002dd069c5 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:488: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002dcfea26 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:305: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dcfe813 10. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002dcbca66 11. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002dcbd104 12. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002dcbd10f 13. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002dcbd10f 14. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x000000002dcb3564 15. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x000000002dcb0bec 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:46:20.096590 [ 8432 ] {cf8504d2-f82e-42a7-95a2-c6f05262034f} executeQuery: Code: 676. DB::Exception: Cannot parse IPv6 .1.2.3: Cannot parse IPv6 from String: In scope SELECT toIPv6('::.1.2.3'). (CANNOT_PARSE_IPV6) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57552) (comment: 02234_cast_to_ip_address.sql) (query 46, line 66) (in query: SELECT toIPv6('::.1.2.3');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x0000000017e3cd4f 5. ./src/IO/ReadHelpers.h:993: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b202aa3 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1fcfc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02e48e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b06326a 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b061fa3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:46:20.138388 [ 8432 ] {} TCPHandler: Code: 676. DB::Exception: Cannot parse IPv6 .1.2.3: Cannot parse IPv6 from String: In scope SELECT toIPv6('::.1.2.3'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x0000000017e3cd4f 5. ./src/IO/ReadHelpers.h:993: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b202aa3 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b1fcfc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02e48e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b06326a 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b061fa3 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:46:20.351950 [ 19621 ] {46268e9b-dabc-4c94-a58a-2f7ecb6341fb} BackupsWorker: Failed to make backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_1.zip'): Code: 60. DB::Exception: Table test_5.data was not found. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:635: DB::BackupEntriesCollector::findTablesInDatabase(String const&) const @ 0x000000002bf084af 6. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:510: DB::BackupEntriesCollector::gatherTablesMetadata() @ 0x000000002befe338 7. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:264: DB::BackupEntriesCollector::tryGatherMetadataAndCompareWithPrevious(int, std::optional&, bool&) @ 0x000000002befaaf4 8. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:226: DB::BackupEntriesCollector::gatherMetadataAndCheckConsistency() @ 0x000000002bef5733 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:147: DB::BackupEntriesCollector::run() @ 0x000000002bef4192 10. ./build_docker/./src/Backups/BackupsWorker.cpp:582: 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&) @ 0x000000002bf3b856 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39173 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e6b 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:20.352799 [ 19621 ] {46268e9b-dabc-4c94-a58a-2f7ecb6341fb} BackupImpl: An error happened, the backup won't be completed 2025.06.13 15:46:20.364248 [ 5112 ] {46268e9b-dabc-4c94-a58a-2f7ecb6341fb} executeQuery: Code: 60. DB::Exception: Table test_5.data was not found. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56490) (comment: 02843_backup_use_same_password_for_base_backup.sh) (query 1, line 1) (in query: BACKUP TABLE data TO Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_1.zip') SETTINGS base_backup=Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_base.zip'),password='password',use_same_password_for_base_backup=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:635: DB::BackupEntriesCollector::findTablesInDatabase(String const&) const @ 0x000000002bf084af 6. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:510: DB::BackupEntriesCollector::gatherTablesMetadata() @ 0x000000002befe338 7. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:264: DB::BackupEntriesCollector::tryGatherMetadataAndCompareWithPrevious(int, std::optional&, bool&) @ 0x000000002befaaf4 8. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:226: DB::BackupEntriesCollector::gatherMetadataAndCheckConsistency() @ 0x000000002bef5733 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:147: DB::BackupEntriesCollector::run() @ 0x000000002bef4192 10. ./build_docker/./src/Backups/BackupsWorker.cpp:582: 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&) @ 0x000000002bf3b856 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:20.432189 [ 5112 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.data was not found. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:635: DB::BackupEntriesCollector::findTablesInDatabase(String const&) const @ 0x000000002bf084af 6. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:510: DB::BackupEntriesCollector::gatherTablesMetadata() @ 0x000000002befe338 7. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:264: DB::BackupEntriesCollector::tryGatherMetadataAndCompareWithPrevious(int, std::optional&, bool&) @ 0x000000002befaaf4 8. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:226: DB::BackupEntriesCollector::gatherMetadataAndCheckConsistency() @ 0x000000002bef5733 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:147: DB::BackupEntriesCollector::run() @ 0x000000002bef4192 10. ./build_docker/./src/Backups/BackupsWorker.cpp:582: 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&) @ 0x000000002bf3b856 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39173 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e6b 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:21.129479 [ 9642 ] {ba3945d1-dce9-4b9b-9000-e7fb6064f2bf} executeQuery: Code: 60. DB::Exception: Table test_5.data does not exist. Maybe you meant test_1.data?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56562) (comment: 02843_backup_use_same_password_for_base_backup.sh) (query 1, line 1) (in query: INSERT INTO data SELECT * FROM numbers(20,10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:21.156955 [ 9642 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.data does not exist. Maybe you meant test_1.data?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:21.868965 [ 6954 ] {e2b4fdff-e8d0-4479-91aa-9d3ced762744} BackupsWorker: Failed to make backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_2.zip'): Code: 60. DB::Exception: Table test_5.data was not found. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:635: DB::BackupEntriesCollector::findTablesInDatabase(String const&) const @ 0x000000002bf084af 6. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:510: DB::BackupEntriesCollector::gatherTablesMetadata() @ 0x000000002befe338 7. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:264: DB::BackupEntriesCollector::tryGatherMetadataAndCompareWithPrevious(int, std::optional&, bool&) @ 0x000000002befaaf4 8. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:226: DB::BackupEntriesCollector::gatherMetadataAndCheckConsistency() @ 0x000000002bef5733 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:147: DB::BackupEntriesCollector::run() @ 0x000000002bef4192 10. ./build_docker/./src/Backups/BackupsWorker.cpp:582: 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&) @ 0x000000002bf3b856 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39173 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e6b 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:21.869968 [ 6954 ] {e2b4fdff-e8d0-4479-91aa-9d3ced762744} BackupImpl: An error happened, the backup won't be completed 2025.06.13 15:46:21.893303 [ 18377 ] {e2b4fdff-e8d0-4479-91aa-9d3ced762744} executeQuery: Code: 60. DB::Exception: Table test_5.data was not found. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56644) (comment: 02843_backup_use_same_password_for_base_backup.sh) (query 1, line 1) (in query: BACKUP TABLE data TO Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_2.zip') SETTINGS base_backup=Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_1.zip'),password='password',use_same_password_for_base_backup=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:635: DB::BackupEntriesCollector::findTablesInDatabase(String const&) const @ 0x000000002bf084af 6. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:510: DB::BackupEntriesCollector::gatherTablesMetadata() @ 0x000000002befe338 7. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:264: DB::BackupEntriesCollector::tryGatherMetadataAndCompareWithPrevious(int, std::optional&, bool&) @ 0x000000002befaaf4 8. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:226: DB::BackupEntriesCollector::gatherMetadataAndCheckConsistency() @ 0x000000002bef5733 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:147: DB::BackupEntriesCollector::run() @ 0x000000002bef4192 10. ./build_docker/./src/Backups/BackupsWorker.cpp:582: 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&) @ 0x000000002bf3b856 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:21.933211 [ 18377 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.data was not found. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:635: DB::BackupEntriesCollector::findTablesInDatabase(String const&) const @ 0x000000002bf084af 6. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:510: DB::BackupEntriesCollector::gatherTablesMetadata() @ 0x000000002befe338 7. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:264: DB::BackupEntriesCollector::tryGatherMetadataAndCompareWithPrevious(int, std::optional&, bool&) @ 0x000000002befaaf4 8. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:226: DB::BackupEntriesCollector::gatherMetadataAndCheckConsistency() @ 0x000000002bef5733 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:147: DB::BackupEntriesCollector::run() @ 0x000000002bef4192 10. ./build_docker/./src/Backups/BackupsWorker.cpp:582: 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&) @ 0x000000002bf3b856 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39173 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e6b 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:22.173031 [ 5978 ] {a2e41e2b-dc98-4fab-b80a-8d13ae6681d7} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toLastDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toLastDayOfMonth(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1415, line 1418) (in query: SELECT toLastDayOfMonth(-1);) 2025.06.13 15:46:22.188584 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toLastDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toLastDayOfMonth(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:22.306010 [ 5978 ] {47a3b60a-c1bc-4b55-88eb-140becd34c58} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toLastDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toLastDayOfWeek(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1416, line 1419) (in query: SELECT toLastDayOfWeek(-1);) 2025.06.13 15:46:22.325353 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toLastDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toLastDayOfWeek(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:22.557216 [ 10895 ] {eaa03f6a-ea2c-4c6f-9e73-a39a4e949da6} BackupsWorker: Failed to make backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_2_bad.zip'): Code: 60. DB::Exception: Table test_5.data was not found. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:635: DB::BackupEntriesCollector::findTablesInDatabase(String const&) const @ 0x000000002bf084af 6. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:510: DB::BackupEntriesCollector::gatherTablesMetadata() @ 0x000000002befe338 7. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:264: DB::BackupEntriesCollector::tryGatherMetadataAndCompareWithPrevious(int, std::optional&, bool&) @ 0x000000002befaaf4 8. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:226: DB::BackupEntriesCollector::gatherMetadataAndCheckConsistency() @ 0x000000002bef5733 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:147: DB::BackupEntriesCollector::run() @ 0x000000002bef4192 10. ./build_docker/./src/Backups/BackupsWorker.cpp:582: 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&) @ 0x000000002bf3b856 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39173 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e6b 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:22.564171 [ 10895 ] {eaa03f6a-ea2c-4c6f-9e73-a39a4e949da6} BackupImpl: An error happened, the backup won't be completed 2025.06.13 15:46:22.591638 [ 3821 ] {eaa03f6a-ea2c-4c6f-9e73-a39a4e949da6} executeQuery: Code: 60. DB::Exception: Table test_5.data was not found. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56678) (comment: 02843_backup_use_same_password_for_base_backup.sh) (query 1, line 1) (in query: BACKUP TABLE data TO Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_2_bad.zip') SETTINGS base_backup=Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_1.zip'),password='password'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:635: DB::BackupEntriesCollector::findTablesInDatabase(String const&) const @ 0x000000002bf084af 6. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:510: DB::BackupEntriesCollector::gatherTablesMetadata() @ 0x000000002befe338 7. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:264: DB::BackupEntriesCollector::tryGatherMetadataAndCompareWithPrevious(int, std::optional&, bool&) @ 0x000000002befaaf4 8. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:226: DB::BackupEntriesCollector::gatherMetadataAndCheckConsistency() @ 0x000000002bef5733 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:147: DB::BackupEntriesCollector::run() @ 0x000000002bef4192 10. ./build_docker/./src/Backups/BackupsWorker.cpp:582: 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&) @ 0x000000002bf3b856 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:22.605460 [ 5978 ] {ef9e9e57-30c0-47b2-9837-f36b6a1e1919} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMillisecond(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1418, line 1421) (in query: SELECT toMillisecond(-1);) 2025.06.13 15:46:22.615072 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMillisecond(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:22.771882 [ 3931 ] {fbd6b870-ef9d-49ee-a0ab-db2c08c07cf0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48530) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (query 80, line 100) (in query: SELECT sum(2 - uint64) From test_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:46:22.789147 [ 3821 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.data was not found. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:635: DB::BackupEntriesCollector::findTablesInDatabase(String const&) const @ 0x000000002bf084af 6. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:510: DB::BackupEntriesCollector::gatherTablesMetadata() @ 0x000000002befe338 7. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:264: DB::BackupEntriesCollector::tryGatherMetadataAndCompareWithPrevious(int, std::optional&, bool&) @ 0x000000002befaaf4 8. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:226: DB::BackupEntriesCollector::gatherMetadataAndCheckConsistency() @ 0x000000002bef5733 9. ./build_docker/./src/Backups/BackupEntriesCollector.cpp:147: DB::BackupEntriesCollector::run() @ 0x000000002bef4192 10. ./build_docker/./src/Backups/BackupsWorker.cpp:582: 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&) @ 0x000000002bf3b856 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x000000002bf5047e 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48363 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39173 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e6b 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:22.814589 [ 3931 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:46:22.819679 [ 5978 ] {7bc6f3e8-cde7-4364-9641-d312ce5d0f15} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMinute(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1419, line 1422) (in query: SELECT toMinute(-1);) 2025.06.13 15:46:22.829201 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMinute(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:22.934724 [ 5978 ] {69e7a2d3-2108-42fb-836c-d6ec79374fe4} executeQuery: Code: 43. DB::Exception: The argument of function toModifiedJulianDay must be String or FixedString: In scope SELECT toModifiedJulianDay(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1420, line 1423) (in query: SELECT toModifiedJulianDay(-1);) 2025.06.13 15:46:23.014751 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The argument of function toModifiedJulianDay must be String or FixedString: In scope SELECT toModifiedJulianDay(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:23.063439 [ 5978 ] {a2adef1a-520a-404f-a7ef-e377089af11d} executeQuery: Code: 43. DB::Exception: The argument of function toModifiedJulianDayOrNull must be String or FixedString: In scope SELECT toModifiedJulianDayOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1421, line 1424) (in query: SELECT toModifiedJulianDayOrNull(-1);) 2025.06.13 15:46:23.079182 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: The argument of function toModifiedJulianDayOrNull must be String or FixedString: In scope SELECT toModifiedJulianDayOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:23.187678 [ 5978 ] {a181c2ad-d4cf-4f15-9942-70ac9f7adf4c} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMonday. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonday(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1422, line 1425) (in query: SELECT toMonday(-1);) 2025.06.13 15:46:23.205427 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMonday. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonday(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:23.216924 [ 19621 ] {d32d2dae-69a1-42fb-b4de-18aba1c11411} BackupsWorker: Failed to restore from backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_1.zip'): Code: 599. DB::Exception: Backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_1.zip') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Backups/BackupImpl.cpp:210: DB::BackupImpl::openArchive() @ 0x000000002bf6cb40 6. ./build_docker/./src/Backups/BackupImpl.cpp:184: DB::BackupImpl::open() @ 0x000000002bf687de 7. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c0643b9 9. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c063146 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06172d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002bf3fa70 12. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4084f 13. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 14. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 16. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39634 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e48 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:23.224967 [ 5112 ] {d32d2dae-69a1-42fb-b4de-18aba1c11411} executeQuery: Code: 599. DB::Exception: Backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_1.zip') not found. (BACKUP_NOT_FOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41842) (comment: 02843_backup_use_same_password_for_base_backup.sh) (query 1, line 1) (in query: RESTORE TABLE data AS data_1 FROM Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_1.zip') SETTINGS password='password',use_same_password_for_base_backup=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Backups/BackupImpl.cpp:210: DB::BackupImpl::openArchive() @ 0x000000002bf6cb40 6. ./build_docker/./src/Backups/BackupImpl.cpp:184: DB::BackupImpl::open() @ 0x000000002bf687de 7. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c0643b9 9. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c063146 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06172d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002bf3fa70 12. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4084f 13. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 14. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 16. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:46:23.293063 [ 5978 ] {6231f8f2-fd74-4504-aff0-502f3d6cc7ca} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonth(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1423, line 1426) (in query: SELECT toMonth(-1);) 2025.06.13 15:46:23.322669 [ 5112 ] {} TCPHandler: Code: 599. DB::Exception: Backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_1.zip') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Backups/BackupImpl.cpp:210: DB::BackupImpl::openArchive() @ 0x000000002bf6cb40 6. ./build_docker/./src/Backups/BackupImpl.cpp:184: DB::BackupImpl::open() @ 0x000000002bf687de 7. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c0643b9 9. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c063146 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06172d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002bf3fa70 12. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4084f 13. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 14. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 16. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39634 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e48 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:23.329392 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonth(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:23.473694 [ 5978 ] {17102d66-260a-4b2c-af1b-162a04ac9596} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMonthNumSinceEpoch. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonthNumSinceEpoch(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1424, line 1427) (in query: SELECT toMonthNumSinceEpoch(-1);) 2025.06.13 15:46:23.480290 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toMonthNumSinceEpoch. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonthNumSinceEpoch(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:23.853819 [ 5978 ] {9556ed99-63db-4d2f-a3ee-1e690c886b58} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toQuarter(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1426, line 1429) (in query: SELECT toQuarter(-1);) 2025.06.13 15:46:23.870785 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toQuarter(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:23.941539 [ 4935 ] {a9d38d52-7cae-4eb3-9b96-3ba8029a5ead} BackupsWorker: Failed to restore from backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_2.zip'): Code: 599. DB::Exception: Backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_2.zip') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Backups/BackupImpl.cpp:210: DB::BackupImpl::openArchive() @ 0x000000002bf6cb40 6. ./build_docker/./src/Backups/BackupImpl.cpp:184: DB::BackupImpl::open() @ 0x000000002bf687de 7. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c0643b9 9. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c063146 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06172d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002bf3fa70 12. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4084f 13. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 14. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 16. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39634 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e48 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:23.957845 [ 8099 ] {a9d38d52-7cae-4eb3-9b96-3ba8029a5ead} executeQuery: Code: 599. DB::Exception: Backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_2.zip') not found. (BACKUP_NOT_FOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41918) (comment: 02843_backup_use_same_password_for_base_backup.sh) (query 1, line 1) (in query: RESTORE TABLE data AS data_2 FROM Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_2.zip') SETTINGS password='password',use_same_password_for_base_backup=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Backups/BackupImpl.cpp:210: DB::BackupImpl::openArchive() @ 0x000000002bf6cb40 6. ./build_docker/./src/Backups/BackupImpl.cpp:184: DB::BackupImpl::open() @ 0x000000002bf687de 7. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c0643b9 9. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c063146 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06172d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002bf3fa70 12. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4084f 13. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 14. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 16. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:46:24.012741 [ 8099 ] {} TCPHandler: Code: 599. DB::Exception: Backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_2.zip') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Backups/BackupImpl.cpp:210: DB::BackupImpl::openArchive() @ 0x000000002bf6cb40 6. ./build_docker/./src/Backups/BackupImpl.cpp:184: DB::BackupImpl::open() @ 0x000000002bf687de 7. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c0643b9 9. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c063146 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06172d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002bf3fa70 12. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4084f 13. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 14. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 16. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39634 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e48 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:24.015572 [ 5978 ] {a56c0261-a915-415f-97b4-10a6cd903d85} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeDayNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeDayNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1427, line 1430) (in query: SELECT toRelativeDayNum(-1);) 2025.06.13 15:46:24.021182 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeDayNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeDayNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:24.176018 [ 5978 ] {af63d2e4-83fc-436a-9973-d19450bad2d7} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeHourNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeHourNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1428, line 1431) (in query: SELECT toRelativeHourNum(-1);) 2025.06.13 15:46:24.204517 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeHourNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeHourNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:24.314128 [ 5978 ] {6f5e90ff-d04c-4294-b82a-24b6e0fa621a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeMinuteNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeMinuteNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1429, line 1432) (in query: SELECT toRelativeMinuteNum(-1);) 2025.06.13 15:46:24.356085 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeMinuteNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeMinuteNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:24.471221 [ 5978 ] {8243b8b1-efd0-49df-9f3f-dd17bec309a9} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeMonthNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeMonthNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1430, line 1433) (in query: SELECT toRelativeMonthNum(-1);) 2025.06.13 15:46:24.488019 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeMonthNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeMonthNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:24.495074 [ 4931 ] {ede22177-8bb2-4e86-ae9b-d1658777844a} BackupsWorker: Failed to restore from backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_2.zip'): Code: 599. DB::Exception: Backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_2.zip') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Backups/BackupImpl.cpp:210: DB::BackupImpl::openArchive() @ 0x000000002bf6cb40 6. ./build_docker/./src/Backups/BackupImpl.cpp:184: DB::BackupImpl::open() @ 0x000000002bf687de 7. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c0643b9 9. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c063146 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06172d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002bf3fa70 12. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4084f 13. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 14. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 16. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39634 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e48 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:24.507301 [ 3894 ] {ede22177-8bb2-4e86-ae9b-d1658777844a} executeQuery: Code: 599. DB::Exception: Backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_2.zip') not found. (BACKUP_NOT_FOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42000) (comment: 02843_backup_use_same_password_for_base_backup.sh) (query 1, line 1) (in query: RESTORE TABLE data AS data_2 FROM Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_2.zip') SETTINGS password='password'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Backups/BackupImpl.cpp:210: DB::BackupImpl::openArchive() @ 0x000000002bf6cb40 6. ./build_docker/./src/Backups/BackupImpl.cpp:184: DB::BackupImpl::open() @ 0x000000002bf687de 7. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c0643b9 9. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c063146 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06172d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002bf3fa70 12. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4084f 13. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 14. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 16. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:46:24.519139 [ 3894 ] {} TCPHandler: Code: 599. DB::Exception: Backup Disk('backups', '02843_backup_use_same_password_for_base_backup_test_5_inc_2.zip') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Backups/BackupImpl.cpp:210: DB::BackupImpl::openArchive() @ 0x000000002bf6cb40 6. ./build_docker/./src/Backups/BackupImpl.cpp:184: DB::BackupImpl::open() @ 0x000000002bf687de 7. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupFactory::CreateParams, DB::BackupImpl::ArchiveParams const&, std::shared_ptr, std::shared_ptr) @ 0x000000002bf676a7 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&>(DB::BackupFactory::CreateParams const&, DB::BackupImpl::ArchiveParams&, std::shared_ptr&) @ 0x000000002c0643b9 9. ./build_docker/./src/Backups/registerBackupEnginesFileAndDisk.cpp:174: DB::registerBackupEnginesFileAndDisk(DB::BackupFactory&)::$_0::operator()(DB::BackupFactory::CreateParams const&) const @ 0x000000002c063146 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002c06172d 11. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002bf3fa70 12. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf4084f 13. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 14. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 16. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39634 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e48 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:24.585524 [ 5978 ] {78432df1-2079-489a-b5de-1b2ad7fb4700} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeQuarterNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeQuarterNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1431, line 1434) (in query: SELECT toRelativeQuarterNum(-1);) 2025.06.13 15:46:24.591986 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeQuarterNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeQuarterNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:24.678832 [ 5978 ] {01b05a58-c5ba-4c2c-a344-d3789b7c67c4} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeSecondNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeSecondNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1432, line 1435) (in query: SELECT toRelativeSecondNum(-1);) 2025.06.13 15:46:24.700966 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeSecondNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeSecondNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:24.831018 [ 5978 ] {aeb90148-459a-4e1c-ade5-6800ee29c51c} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeWeekNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeWeekNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1433, line 1436) (in query: SELECT toRelativeWeekNum(-1);) 2025.06.13 15:46:24.834904 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeWeekNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeWeekNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:24.940048 [ 5978 ] {41d16e5b-ffc6-4481-9f4a-5ee45f0ec89b} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeYearNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeYearNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1434, line 1437) (in query: SELECT toRelativeYearNum(-1);) 2025.06.13 15:46:24.953376 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toRelativeYearNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeYearNum(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:25.008959 [ 5110 ] {b9aeaa27-5f6f-449d-b4ec-de8d17fd22de} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'data_1' in scope SELECT COUNT(*) FROM data_1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42060) (comment: 02843_backup_use_same_password_for_base_backup.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM data_1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:25.026298 [ 5110 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'data_1' in scope SELECT COUNT(*) FROM data_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:25.040402 [ 5978 ] {48ee5f7b-14d7-4dc7-9329-864c4c836053} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toSecond(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1435, line 1438) (in query: SELECT toSecond(-1);) 2025.06.13 15:46:25.051444 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toSecond(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:25.235401 [ 5978 ] {ed52a122-9219-46cb-ae6c-4b553c8108f2} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfDay. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfDay(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1436, line 1439) (in query: SELECT toStartOfDay(-1);) 2025.06.13 15:46:25.267713 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfDay. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfDay(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:25.466494 [ 5978 ] {771e9146-aea7-40dc-b752-e1cf0a0484c0} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfFifteenMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFifteenMinutes(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1437, line 1440) (in query: SELECT toStartOfFifteenMinutes(-1);) 2025.06.13 15:46:25.480291 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfFifteenMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFifteenMinutes(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:25.656564 [ 5978 ] {21ac4972-b331-45ed-b92c-8abbb5fbff57} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfFiveMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFiveMinute(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1438, line 1441) (in query: SELECT toStartOfFiveMinute(-1);) 2025.06.13 15:46:25.661630 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfFiveMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFiveMinute(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:25.691420 [ 4171 ] {1589ffdf-36c8-4b01-8370-c782c56f5d37} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'data_2' in scope SELECT COUNT(*) FROM data_2. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42132) (comment: 02843_backup_use_same_password_for_base_backup.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM data_2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:25.710883 [ 4171 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'data_2' in scope SELECT COUNT(*) FROM data_2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:25.800869 [ 5978 ] {b5c3c795-f5e8-49ee-bc96-9e5119528421} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfFiveMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFiveMinutes(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1439, line 1442) (in query: SELECT toStartOfFiveMinutes(-1);) 2025.06.13 15:46:25.821792 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfFiveMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFiveMinutes(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:25.975778 [ 5978 ] {3f4bd3a3-bd01-481d-b817-e5f41bf3a512} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfHour(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1440, line 1443) (in query: SELECT toStartOfHour(-1);) 2025.06.13 15:46:25.978457 [ 3894 ] {3c2854ff-f0cb-4255-921c-1e5a5a614e86} 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.20286.altinityantalya (altinity build)) (from [::1]:42106) (comment: 03279_pr_3_way_joins_right_first.gen.sql) (query 5, line 6) (in query: CREATE TABLE test_table_join_1 (`id_1` UInt8, `value_1` String) ENGINE = ReplicatedMergeTree('/clickhouse/{database}/test_table_join_1', 'r1') ORDER BY id_1 SETTINGS index_granularity = 1, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 326023736, compact_parts_max_granules_to_buffer = 232, compact_parts_merge_max_bytes_to_prefetch_part = 9865665, merge_max_block_size = 14836, old_parts_lifetime = 269., 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 = 3156518565, index_granularity_bytes = 22188066, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 94548, primary_key_compress_block_size = 14224, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:25.980872 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfHour(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:25.997715 [ 3894 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:26.176516 [ 5978 ] {363ef9eb-17b5-4f7a-af0a-b2fbeb76eccb} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfISOYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfISOYear(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1441, line 1444) (in query: SELECT toStartOfISOYear(-1);) 2025.06.13 15:46:26.184142 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfISOYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfISOYear(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:26.233603 [ 8099 ] {8c3a60a4-46dd-41f3-a7a0-09b6b5f89671} executeQuery: Code: 691. DB::Exception: Unknown element 'xyz' for enum: while converting 'xyz' to Enum8('hello' = 1, 'world' = 2). (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42008) (comment: 01310_enum_comparison.sql) (query 7, line 9) (in query: SELECT count() FROM enum WHERE x = 'xyz';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04442f 5. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x000000002c4c2f61 6. ./build_docker/./src/DataTypes/Serializations/SerializationEnum.cpp:99: DB::SerializationEnum<_BitInt(8)>::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c593739 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e257bab 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 18. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 19. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 21. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 22. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 23. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:46:26.261669 [ 8099 ] {} TCPHandler: Code: 691. DB::Exception: Unknown element 'xyz' for enum: while converting 'xyz' to Enum8('hello' = 1, 'world' = 2). (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04442f 5. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x000000002c4c2f61 6. ./build_docker/./src/DataTypes/Serializations/SerializationEnum.cpp:99: DB::SerializationEnum<_BitInt(8)>::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c593739 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e257bab 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 18. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 19. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 21. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 22. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 23. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:46:26.305057 [ 5978 ] {7230d7b9-3c55-4efd-b082-8f7ce5b5832e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 1, must be 2, 3 or 4: In scope SELECT toStartOfInterval(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1442, line 1445) (in query: SELECT toStartOfInterval(-1);) 2025.06.13 15:46:26.329151 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 1, must be 2, 3 or 4: In scope SELECT toStartOfInterval(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:26.338771 [ 8101 ] {91b6667e-6aca-402c-81e1-e759d9f14065} executeQuery: Code: 43. DB::Exception: Illegal types Date and Date of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 367, line 367) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N + N as r FORMAT CSV;) 2025.06.13 15:46:26.349841 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and Date of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:26.404898 [ 5978 ] {9e4012c1-0bee-4a8e-bf46-d9b5271334dc} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfMicrosecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMicrosecond(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1443, line 1446) (in query: SELECT toStartOfMicrosecond(-1);) 2025.06.13 15:46:26.422058 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfMicrosecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMicrosecond(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:26.517243 [ 8101 ] {477eb0ce-af1a-45a8-aa1f-c4f976f6d275} executeQuery: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and DateTime('Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 368, line 368) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), N + N as r FORMAT CSV;) 2025.06.13 15:46:26.531781 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and DateTime('Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:26.572704 [ 5978 ] {e6cba39c-e42e-48d0-b14c-7f395f183d1d} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMillisecond(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1444, line 1447) (in query: SELECT toStartOfMillisecond(-1);) 2025.06.13 15:46:26.579584 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMillisecond(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:26.642658 [ 8101 ] {59ab6690-352f-41b2-bbe9-e9fb5f62cc0e} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 369, line 369) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), N + N as r FORMAT CSV;) 2025.06.13 15:46:26.652898 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:26.662521 [ 5978 ] {e26597a6-7fdf-4ee6-b656-93323f6e63c6} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMinute(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1445, line 1448) (in query: SELECT toStartOfMinute(-1);) 2025.06.13 15:46:26.690034 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMinute(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:26.854411 [ 5978 ] {83cba581-f01a-4660-8e62-7b8f1f104710} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMonth(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1446, line 1449) (in query: SELECT toStartOfMonth(-1);) 2025.06.13 15:46:26.863905 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMonth(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:26.946155 [ 5978 ] {e60a0eb7-cdaf-43cc-9d71-329db9856d00} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfNanosecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfNanosecond(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1447, line 1450) (in query: SELECT toStartOfNanosecond(-1);) 2025.06.13 15:46:26.966728 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfNanosecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfNanosecond(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:27.076176 [ 5978 ] {18f3578f-7d69-4e55-9bd6-8b7aa76d62c3} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfQuarter(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1448, line 1451) (in query: SELECT toStartOfQuarter(-1);) 2025.06.13 15:46:27.089200 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfQuarter(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:27.204138 [ 5978 ] {ab3edf1e-8b5b-4b64-81c1-a200d5fe98bd} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfSecond(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1449, line 1452) (in query: SELECT toStartOfSecond(-1);) 2025.06.13 15:46:27.214135 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfSecond(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:27.312618 [ 5978 ] {fa9322e2-fc41-400b-86b3-d0f9796ae3e8} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfTenMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfTenMinutes(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1450, line 1453) (in query: SELECT toStartOfTenMinutes(-1);) 2025.06.13 15:46:27.320889 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfTenMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfTenMinutes(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:27.407394 [ 5978 ] {689cc44a-b7d2-42a0-9b3c-60e866ed3cf3} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toStartOfWeek(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1451, line 1454) (in query: SELECT toStartOfWeek(-1);) 2025.06.13 15:46:27.423870 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toStartOfWeek(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:27.534815 [ 5978 ] {e9d3a43a-8346-48c9-a179-cb1c45d70f62} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfYear(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1452, line 1455) (in query: SELECT toStartOfYear(-1);) 2025.06.13 15:46:27.548574 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStartOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfYear(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:27.980203 [ 5978 ] {328d7b96-71a9-4d80-81b0-8cbed6c3e8ea} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStringCutToZero: In scope SELECT toStringCutToZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1454, line 1457) (in query: SELECT toStringCutToZero(-1);) 2025.06.13 15:46:27.997114 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toStringCutToZero: In scope SELECT toStringCutToZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:28.125009 [ 5978 ] {64b7191e-c99a-40a4-8474-812b71f54451} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toTime. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toTime(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1455, line 1458) (in query: SELECT toTime(-1);) 2025.06.13 15:46:28.139857 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toTime. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toTime(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:28.200047 [ 8432 ] {2d1cb7dd-59af-43d5-b807-b9f5571732c3} executeQuery: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT CAST('test', 'IPv6'). (CANNOT_PARSE_IPV6) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57552) (comment: 02234_cast_to_ip_address.sql) (query 51, line 74) (in query: SELECT cast('test' , 'IPv6');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000002adc3631 6. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000002adc04ca 7. bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002adbfdf9 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adbfbc2 9. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:46:28.246863 [ 8432 ] {} TCPHandler: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT CAST('test', 'IPv6'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000002adc3631 6. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000002adc04ca 7. bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002adbfdf9 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002adbfbc2 9. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 10. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:46:28.282006 [ 5978 ] {39fc62f0-bd6e-4c6f-9fb3-20b76fd6f10c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 1, should be 2: In scope SELECT toTimeZone(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1456, line 1459) (in query: SELECT toTimeZone(-1);) 2025.06.13 15:46:28.289936 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 1, should be 2: In scope SELECT toTimeZone(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:28.461225 [ 5978 ] {911af754-8d2e-4e67-8ed1-951d32f23249} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 1, should be 2: In scope SELECT toTimezone(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1457, line 1460) (in query: SELECT toTimezone(-1);) 2025.06.13 15:46:28.473636 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 1, should be 2: In scope SELECT toTimezone(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:29.372384 [ 5978 ] {5a8e1fd9-73cc-47f7-a50e-f254a73996cd} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt128OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt128OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1461, line 1464) (in query: SELECT toUInt128OrNull(-1);) 2025.06.13 15:46:29.397059 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt128OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt128OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:29.499516 [ 5978 ] {9c3d501f-d327-4774-a922-9a8ee6a45a30} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt128OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt128OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1462, line 1465) (in query: SELECT toUInt128OrZero(-1);) 2025.06.13 15:46:29.545155 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt128OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt128OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:30.106125 [ 7755 ] {fb7fc08e-220d-463f-afd4-53696b6fa47b} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42148) (comment: 01019_alter_materialized_view_query.sql) (query 15, line 33) (in query: DROP TABLE src_01019;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:30.124179 [ 7755 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:30.182204 [ 5978 ] {d6f83b7d-aa66-4f15-80a2-c731c3dcf1a6} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt16OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1465, line 1468) (in query: SELECT toUInt16OrNull(-1);) 2025.06.13 15:46:30.203228 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt16OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:30.325769 [ 5978 ] {b3c96ae4-f168-465b-b088-25f623c4ed90} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt16OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1466, line 1469) (in query: SELECT toUInt16OrZero(-1);) 2025.06.13 15:46:30.340060 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt16OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:30.858820 [ 9644 ] {ca80b744-3e63-4f30-9461-99aa665707d0} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42458) (comment: 03277_analyzer_array_join_fix.sql) (query 1, line 1) (in query: CREATE TABLE IF NOT EXISTS repro (`a` LowCardinality(String), `foos` Nested(x LowCardinality(String))) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31663, min_bytes_for_wide_part = 452387198, ratio_of_defaults_for_sparse_serialization = 0.6535395979881287, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 259758427, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 22145189, merge_max_block_size = 17867, old_parts_lifetime = 438., 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 = 6601849486, index_granularity_bytes = 19382105, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 24, 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 = 87286, primary_key_compress_block_size = 74915, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:30.881246 [ 9644 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:30.911881 [ 5978 ] {d63cedd1-157b-4d1a-8f33-d53a06528541} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt256OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt256OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1469, line 1472) (in query: SELECT toUInt256OrNull(-1);) 2025.06.13 15:46:30.945434 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt256OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt256OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:31.078675 [ 5978 ] {964f6e2a-1ab7-43b1-9a38-c03bc9a801e5} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt256OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt256OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1470, line 1473) (in query: SELECT toUInt256OrZero(-1);) 2025.06.13 15:46:31.086950 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt256OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt256OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:31.240444 [ 7279 ] {} DynamicQueryHandler: Code: 372. DB::Exception: Session 03373_session_test_1_24273.24653 not found. (SESSION_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Interpreters/Session.cpp:122: DB::NamedSessionsStorage::acquireSession(std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&, String const&, std::chrono::duration>, bool) @ 0x000000002df3134e 6. ./build_docker/./src/Interpreters/Session.cpp:586: DB::Session::makeSessionContext(String const&, std::chrono::duration>, bool) @ 0x000000002df2d4f4 7. ./build_docker/./src/Server/HTTPHandler.cpp:247: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b32e4 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:31.784850 [ 5978 ] {8293180d-017b-4a29-b53d-15f0cfa5fb75} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt32OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1473, line 1476) (in query: SELECT toUInt32OrNull(-1);) 2025.06.13 15:46:31.805516 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt32OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:31.940229 [ 5978 ] {92d29b8c-c527-49d4-8fcd-a7bc3ca49881} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt32OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1474, line 1477) (in query: SELECT toUInt32OrZero(-1);) 2025.06.13 15:46:31.961266 [ 6234 ] {c76d6cd2-a5fe-43e2-a520-9596a0664daf} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42522) (comment: 01210_drop_view.sql) (query 4, line 5) (in query: CREATE VIEW IF NOT EXISTS v_01210 AS SELECT 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:31.974330 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt32OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:31.998534 [ 6234 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:32.579807 [ 5978 ] {f695e0d3-7d6e-49b5-885c-e2f5cea399f1} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt64OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1477, line 1480) (in query: SELECT toUInt64OrNull(-1);) 2025.06.13 15:46:32.586290 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt64OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:32.706332 [ 5978 ] {04e0b1dd-8728-427d-9a13-47366caea27d} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt64OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1478, line 1481) (in query: SELECT toUInt64OrZero(-1);) 2025.06.13 15:46:32.715711 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt64OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:33.287442 [ 5978 ] {dde4362f-8ce5-4255-bfaf-eda6c6e8cbd9} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1481, line 1484) (in query: SELECT toUInt8OrNull(-1);) 2025.06.13 15:46:33.305363 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:33.453904 [ 5978 ] {a24adf07-7add-4759-91a7-8b28cd821429} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt8OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1482, line 1485) (in query: SELECT toUInt8OrZero(-1);) 2025.06.13 15:46:33.489180 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUInt8OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:33.565793 [ 8101 ] {1d146a6e-5a6b-471b-a8c6-3e1214431c27} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 402, line 402) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N - DT as r FORMAT CSV;) 2025.06.13 15:46:33.575326 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:33.650151 [ 5978 ] {3ff5aecc-da57-428c-a703-e378c532b305} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT toUTCTimestamp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1483, line 1486) (in query: SELECT toUTCTimestamp(-1);) 2025.06.13 15:46:33.654776 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT toUTCTimestamp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:33.745314 [ 5978 ] {60729432-e726-4b29-a899-96f7d043518f} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUUID(-1). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1484, line 1487) (in query: SELECT toUUID(-1);) 2025.06.13 15:46:33.753444 [ 5978 ] {} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUUID(-1). (NOT_IMPLEMENTED) 2025.06.13 15:46:33.947025 [ 5978 ] {1dc7e439-990c-434b-93dc-d722a1b3ac38} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUUIDOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUUIDOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1486, line 1489) (in query: SELECT toUUIDOrNull(-1);) 2025.06.13 15:46:33.992797 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUUIDOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUUIDOrNull(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:34.086023 [ 5978 ] {3436a3a9-6117-4c4f-8299-70f3a1a1968d} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUUIDOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUUIDOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1487, line 1490) (in query: SELECT toUUIDOrZero(-1);) 2025.06.13 15:46:34.093890 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of first argument of function toUUIDOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUUIDOrZero(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:34.347946 [ 5978 ] {13d99bb3-c97d-4b10-aeb2-2701863bd3fe} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Micro'. Expected: DateTime64, got: Int8: In scope SELECT toUnixTimestamp64Micro(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1489, line 1492) (in query: SELECT toUnixTimestamp64Micro(-1);) 2025.06.13 15:46:34.379322 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Micro'. Expected: DateTime64, got: Int8: In scope SELECT toUnixTimestamp64Micro(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:34.439940 [ 8101 ] {00f4586b-7bbd-42ae-ae5f-a09f3042d0ae} executeQuery: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 407, line 407) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), DT - N as r FORMAT CSV;) 2025.06.13 15:46:34.448995 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:34.503073 [ 5978 ] {3ec2df58-a7c7-405d-b93f-6e66d6834af4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Milli'. Expected: DateTime64, got: Int8: In scope SELECT toUnixTimestamp64Milli(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1490, line 1493) (in query: SELECT toUnixTimestamp64Milli(-1);) 2025.06.13 15:46:34.511773 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Milli'. Expected: DateTime64, got: Int8: In scope SELECT toUnixTimestamp64Milli(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:34.656023 [ 5978 ] {f627cbd6-3946-45de-988c-bc0daf0423da} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Nano'. Expected: DateTime64, got: Int8: In scope SELECT toUnixTimestamp64Nano(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1491, line 1494) (in query: SELECT toUnixTimestamp64Nano(-1);) 2025.06.13 15:46:34.660593 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Nano'. Expected: DateTime64, got: Int8: In scope SELECT toUnixTimestamp64Nano(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:34.725194 [ 5978 ] {3190c00c-496a-4981-9708-bb29cdbe7945} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Second'. Expected: DateTime64, got: Int8: In scope SELECT toUnixTimestamp64Second(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1492, line 1495) (in query: SELECT toUnixTimestamp64Second(-1);) 2025.06.13 15:46:34.737538 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Second'. Expected: DateTime64, got: Int8: In scope SELECT toUnixTimestamp64Second(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:34.812663 [ 5978 ] {63082ef7-b0d3-458f-977a-c4c127198b18} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toValidUTF8: In scope SELECT toValidUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1493, line 1496) (in query: SELECT toValidUTF8(-1);) 2025.06.13 15:46:34.822514 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toValidUTF8: In scope SELECT toValidUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:34.860483 [ 10892 ] {} test_o5hhwim2.test_03093 (0217add8-b8ee-4c4c-ba85-c02b0b3389fe): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.13 15:46:34.863593 [ 10892 ] {} DatabaseCatalog: Cannot drop table test_o5hhwim2.test_03093 (0217add8-b8ee-4c4c-ba85-c02b0b3389fe). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cafe6a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030caed0f 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cbb267 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d5f99b1 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d607d44 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:34.901598 [ 5978 ] {466171a7-6d67-41b8-8a54-243fe7123c83} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toWeek(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1494, line 1497) (in query: SELECT toWeek(-1);) 2025.06.13 15:46:34.911994 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toWeek(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:34.974769 [ 8430 ] {0ebb0a95-0f90-4786-87fa-db5b6b79efa9} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49594) (comment: 01338_long_select_and_alter.sh) (query 1, line 1) (in query: CREATE TABLE alter_mt (key Int64, value String) ENGINE=MergeTree() ORDER BY key), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:34.989120 [ 5978 ] {0dde2785-3e7f-4a4d-a6f6-578872f67ee6} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYYYYMM. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMM(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1495, line 1498) (in query: SELECT toYYYYMM(-1);) 2025.06.13 15:46:35.010699 [ 8430 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:35.011895 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYYYYMM. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMM(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:35.086996 [ 5110 ] {1bb3d7a1-e22c-46a3-8014-efbaeac7caee} executeQuery: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49500) (comment: 03271_date_to_datetime_saturation.sql) (query 6, line 9) (in query: optimize table test final;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab57af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab1fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003122f56b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d8e4 8. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 10. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:35.107375 [ 5110 ] {} TCPHandler: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab57af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab1fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003122f56b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d8e4 8. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 10. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:35.119379 [ 5978 ] {2fea7c09-a90c-404c-abf6-612160053ad5} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYYYYMMDD. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMMDD(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1496, line 1499) (in query: SELECT toYYYYMMDD(-1);) 2025.06.13 15:46:35.167652 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYYYYMMDD. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMMDD(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:35.257309 [ 5978 ] {9ce6d91f-3343-4ec2-bf82-cda3c8099ffd} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYYYYMMDDhhmmss. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMMDDhhmmss(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1497, line 1500) (in query: SELECT toYYYYMMDDhhmmss(-1);) 2025.06.13 15:46:35.268470 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYYYYMMDDhhmmss. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMMDDhhmmss(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:35.449183 [ 5978 ] {c75e8163-758d-482e-ae6e-adff178d4a14} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYear(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1498, line 1501) (in query: SELECT toYear(-1);) 2025.06.13 15:46:35.463592 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYear(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:35.509849 [ 8101 ] {8a7891b9-a69e-4817-a5dd-0f50159697ea} executeQuery: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 413, line 413) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), N - D as r FORMAT CSV;) 2025.06.13 15:46:35.522476 [ 8099 ] {a40b9412-afad-49e8-9c9f-4411f04d9150} executeQuery: Code: 60. DB::Exception: Table test_7.alter_mt does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49648) (comment: 01338_long_select_and_alter.sh) (query 1, line 1) (in query: INSERT INTO alter_mt SELECT number - 1 AS x, toString(x) FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:35.523194 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:35.530335 [ 8099 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.alter_mt does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:35.540071 [ 5978 ] {fe6864bc-9d80-492f-9523-ff23ebbfdedf} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYearNumSinceEpoch. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYearNumSinceEpoch(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1499, line 1502) (in query: SELECT toYearNumSinceEpoch(-1);) 2025.06.13 15:46:35.559528 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYearNumSinceEpoch. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYearNumSinceEpoch(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:35.623211 [ 8101 ] {66cd9021-554c-446a-a8f2-9df1115fb98b} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 414, line 414) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), N - D as r FORMAT CSV;) 2025.06.13 15:46:35.625820 [ 5978 ] {4b468a97-7a1f-4c1e-88c1-2400ee020df2} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toYearWeek(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1500, line 1503) (in query: SELECT toYearWeek(-1);) 2025.06.13 15:46:35.627898 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:35.642910 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toYearWeek(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:35.820622 [ 5978 ] {2bfbdb7f-a536-46ee-8326-f068c215b3f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT to_utc_timestamp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1501, line 1504) (in query: SELECT to_utc_timestamp(-1);) 2025.06.13 15:46:35.835740 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 1, should be 2: In scope SELECT to_utc_timestamp(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:35.997872 [ 5978 ] {165c6908-22fd-4113-9266-3c28294d6fd0} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 1, should be 0: In scope SELECT today(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1502, line 1505) (in query: SELECT today(-1);) 2025.06.13 15:46:36.016236 [ 4171 ] {1509b876-ca94-4549-952f-5dc579582250} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'alter_mt' in scope SELECT countDistinct(concat(value, '_')) FROM alter_mt WHERE NOT sleepEachRow(2). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49720) (comment: 01338_long_select_and_alter.sh) (query 1, line 1) (in query: SELECT count(distinct concat(value, '_')) FROM alter_mt WHERE not sleepEachRow(2)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:36.020531 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 1, should be 0: In scope SELECT today(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:36.032141 [ 4171 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'alter_mt' in scope SELECT countDistinct(concat(value, '_')) FROM alter_mt WHERE NOT sleepEachRow(2). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:36.213294 [ 5978 ] {0c2842d3-7a7b-4c00-a233-5d75a7e98179} executeQuery: Code: 36. DB::Exception: Function tokens first argument type should be String or FixedString. Actual Int8: In scope SELECT tokens(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1503, line 1506) (in query: SELECT tokens(-1);) 2025.06.13 15:46:36.226812 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: Function tokens first argument type should be String or FixedString. Actual Int8: In scope SELECT tokens(-1). (BAD_ARGUMENTS) 2025.06.13 15:46:36.434804 [ 18380 ] {e9be0d32-b027-49a6-b241-0d2ffe071f04} executeQuery: Code: 583. DB::Exception: When aggregation is used in projection, ORDER BY cannot be specified. (ILLEGAL_PROJECTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49718) (comment: 01710_projection_group_by_order_by.sql) (query 3, line 8) (in query: create table tp (type Int32, eventcnt UInt64, projection p (select sum(eventcnt), type group by type order by sum(eventcnt))) engine = MergeTree order by type;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/ProjectionsDescription.cpp:135: DB::ProjectionDescription::getProjectionFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003035dc3f 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:811: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5f1c1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:36.449675 [ 18380 ] {} TCPHandler: Code: 583. DB::Exception: When aggregation is used in projection, ORDER BY cannot be specified. (ILLEGAL_PROJECTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/ProjectionsDescription.cpp:135: DB::ProjectionDescription::getProjectionFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003035dc3f 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:811: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5f1c1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:36.460739 [ 6193 ] {1aab710d-a616-42a8-a3c8-4132a5f2db39} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49738) (comment: 02998_attach_partition_not_allowed_if_structure_differs_due_to_materialized_column.sql) (query 1, line 1) (in query: CREATE TABLE attach_partition_t7 (`a` UInt32, `b` UInt32) ENGINE = MergeTree PARTITION BY a ORDER BY a SETTINGS index_granularity = 57405, 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 = 340781284, compact_parts_max_bytes_to_buffer = 72058041, compact_parts_max_granules_to_buffer = 37, compact_parts_merge_max_bytes_to_prefetch_part = 11509864, merge_max_block_size = 10861, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 30361529, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 61251, primary_key_compress_block_size = 30751, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:36.467823 [ 4171 ] {8c492bc0-80ce-41cd-b7f0-ac14e1f53d81} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49748) (comment: 01825_type_json_9.sql) (query 2, line 5) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:36.468363 [ 6193 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:36.478119 [ 8101 ] {0ed4675e-b2a3-4484-abb9-eadc04efccaf} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 418, line 418) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), D - N as r FORMAT CSV;) 2025.06.13 15:46:36.490307 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:36.499361 [ 4171 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:36.548604 [ 8101 ] {5bba5dde-7d04-4ba7-ad60-0f96c844a2aa} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 419, line 419) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), D - N as r FORMAT CSV;) 2025.06.13 15:46:36.551353 [ 5978 ] {36db84ba-100e-4fb0-aec7-d16a63624a23} executeQuery: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1505, line 1508) (in query: SELECT topKWeighted(-1);) 2025.06.13 15:46:36.555047 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:36.571936 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:36.707538 [ 5978 ] {e838176f-bea5-4c6a-a83c-8e12d308111a} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function topLevelDomain: In scope SELECT topLevelDomain(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1506, line 1509) (in query: SELECT topLevelDomain(-1);) 2025.06.13 15:46:36.725227 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function topLevelDomain: In scope SELECT topLevelDomain(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:36.885091 [ 5978 ] {5bc34d8b-0a57-47ca-838d-671da9d8a338} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function topLevelDomainRFC: In scope SELECT topLevelDomainRFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1507, line 1510) (in query: SELECT topLevelDomainRFC(-1);) 2025.06.13 15:46:36.893335 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function topLevelDomainRFC: In scope SELECT topLevelDomainRFC(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:36.976106 [ 3894 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: non_exist_user: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:36.977805 [ 3894 ] {} ServerErrorHandler: Code: 516. DB::Exception: non_exist_user: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:37.000830 [ 5978 ] {edd71a75-1498-40fe-a056-6c53e01eca65} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 1, should be 0: In scope SELECT transactionID(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1508, line 1511) (in query: SELECT transactionID(-1);) 2025.06.13 15:46:37.018629 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 1, should be 0: In scope SELECT transactionID(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:37.036058 [ 8101 ] {f755fa5c-0cd4-47bc-93ea-83c54245d739} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT64 AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 422, line 422) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N - DT64 as r FORMAT CSV;) 2025.06.13 15:46:37.045957 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT64 AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:37.167071 [ 5978 ] {f96f2d8d-b800-4a6c-a3f3-e30132c9a6fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 1, should be 0: In scope SELECT transactionLatestSnapshot(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1509, line 1512) (in query: SELECT transactionLatestSnapshot(-1);) 2025.06.13 15:46:37.204028 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 1, should be 0: In scope SELECT transactionLatestSnapshot(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:37.223138 [ 5163 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:37.224197 [ 5163 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:37.414061 [ 5978 ] {353eb42f-e4ff-495f-9ae9-cc714f0fda9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 1, should be 0: In scope SELECT transactionOldestSnapshot(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1510, line 1513) (in query: SELECT transactionOldestSnapshot(-1);) 2025.06.13 15:46:37.419799 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 1, should be 0: In scope SELECT transactionOldestSnapshot(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:37.572123 [ 5978 ] {1dbc3bca-3a2e-43f1-8fc2-2ed173b44d71} executeQuery: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 1, should be 3 or 4: In scope SELECT transform(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1511, line 1514) (in query: SELECT transform(-1);) 2025.06.13 15:46:37.588424 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 1, should be 3 or 4: In scope SELECT transform(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:37.889651 [ 5978 ] {ac653730-31a7-46f2-9f34-0ce0f7bb115f} executeQuery: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 1, should be 3: In scope SELECT translate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1512, line 1515) (in query: SELECT translate(-1);) 2025.06.13 15:46:37.896263 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 1, should be 3: In scope SELECT translate(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:38.028457 [ 5978 ] {be5c08e7-8ab2-4c73-9dfe-4d120c4ca743} executeQuery: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 1, should be 3: In scope SELECT translateUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1513, line 1516) (in query: SELECT translateUTF8(-1);) 2025.06.13 15:46:38.043897 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 1, should be 3: In scope SELECT translateUTF8(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:38.200303 [ 5978 ] {effbf5b9-e2fe-4259-8bdd-4dac42d696ec} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimBoth'. Expected: String, got: Int8: In scope SELECT trimBoth(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1514, line 1517) (in query: SELECT trim(-1);) 2025.06.13 15:46:38.240101 [ 8101 ] {64c08e5b-487f-43eb-be89-59aa1d4ee397} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT64 - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 427, line 427) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), DT64 - N as r FORMAT CSV;) 2025.06.13 15:46:38.240284 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimBoth'. Expected: String, got: Int8: In scope SELECT trimBoth(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:38.268670 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT64 - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:38.332895 [ 3931 ] {f6a52573-7716-4361-9bc5-c7446d1239fa} executeQuery: Code: 60. DB::Exception: Could not find table: alter_mt. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49908) (comment: 01338_long_select_and_alter.sh) (query 1, line 1) (in query: ALTER TABLE alter_mt MODIFY COLUMN value Int64), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:46:38.359198 [ 3931 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_mt. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:46:38.438128 [ 5978 ] {71e28c09-a422-4252-a91c-c1af271f1267} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimBoth'. Expected: String, got: Int8: In scope SELECT trimBoth(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1515, line 1518) (in query: SELECT trimBoth(-1);) 2025.06.13 15:46:38.466583 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimBoth'. Expected: String, got: Int8: In scope SELECT trimBoth(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:38.567367 [ 5978 ] {ec4b6c17-30d9-4092-a463-e426defa35bf} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimLeft'. Expected: String, got: Int8: In scope SELECT trimLeft(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1516, line 1519) (in query: SELECT trimLeft(-1);) 2025.06.13 15:46:38.590055 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimLeft'. Expected: String, got: Int8: In scope SELECT trimLeft(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:38.748599 [ 5978 ] {cb7d8a2a-8612-486b-8b5d-922271e6d090} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimRight'. Expected: String, got: Int8: In scope SELECT trimRight(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1517, line 1520) (in query: SELECT trimRight(-1);) 2025.06.13 15:46:38.756812 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimRight'. Expected: String, got: Int8: In scope SELECT trimRight(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:38.860186 [ 7755 ] {3891ad52-ec24-4b87-9d63-2c72508ade68} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'alter_mt' in scope SELECT sum(value) FROM alter_mt. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49924) (comment: 01338_long_select_and_alter.sh) (query 1, line 1) (in query: SELECT sum(value) FROM alter_mt), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:38.887998 [ 7755 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'alter_mt' in scope SELECT sum(value) FROM alter_mt. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:39.216168 [ 5978 ] {8dcf8d07-bd13-4e8e-8ac1-9070965b1d45} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'arg' to function 'tryBase58Decode'. Expected: String or FixedString, got: Int8: In scope SELECT tryBase58Decode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1520, line 1523) (in query: SELECT tryBase58Decode(-1);) 2025.06.13 15:46:39.245081 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'arg' to function 'tryBase58Decode'. Expected: String or FixedString, got: Int8: In scope SELECT tryBase58Decode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:39.404862 [ 5978 ] {c39da332-f1bd-4a3e-8037-85b66b5118ed} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'tryBase64Decode'. Expected: String or FixedString, got: Int8: In scope SELECT tryBase64Decode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1521, line 1524) (in query: SELECT tryBase64Decode(-1);) 2025.06.13 15:46:39.407749 [ 7755 ] {e82e1cd1-949d-454c-9e8f-d9386ac50f50} executeQuery: Code: 390. DB::Exception: Table `alter_mt` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49940) (comment: 01338_long_select_and_alter.sh) (query 1, line 1) (in query: SHOW CREATE TABLE alter_mt), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002c725068 6. ./src/Databases/IDatabase.h:350: DB::IDatabase::getCreateTableQuery(String const&, std::shared_ptr) const @ 0x000000002c029e21 7. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:66: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000002e32b399 8. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x000000002e32abcc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:39.429929 [ 7755 ] {} TCPHandler: Code: 390. DB::Exception: Table `alter_mt` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002c725068 6. ./src/Databases/IDatabase.h:350: DB::IDatabase::getCreateTableQuery(String const&, std::shared_ptr) const @ 0x000000002c029e21 7. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:66: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000002e32b399 8. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x000000002e32abcc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:39.432604 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'tryBase64Decode'. Expected: String or FixedString, got: Int8: In scope SELECT tryBase64Decode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:39.603423 [ 5978 ] {4675f5de-ddda-4605-ab7c-d40c99f7cad5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'tryBase64URLDecode'. Expected: String or FixedString, got: Int8: In scope SELECT tryBase64URLDecode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1522, line 1525) (in query: SELECT tryBase64URLDecode(-1);) 2025.06.13 15:46:39.660751 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'tryBase64URLDecode'. Expected: String or FixedString, got: Int8: In scope SELECT tryBase64URLDecode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:39.774562 [ 5978 ] {85701e0a-2104-408c-ac34-b1c582b9059d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'tryDecrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT tryDecrypt(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1523, line 1526) (in query: SELECT tryDecrypt(-1);) 2025.06.13 15:46:39.800059 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'tryDecrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 1 argument: In scope SELECT tryDecrypt(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:39.939052 [ 5978 ] {fb3bc8a4-6bcd-4c04-9b0c-9a6dafc302d5} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function tryIdnaEncode: In scope SELECT tryIdnaEncode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1524, line 1527) (in query: SELECT tryIdnaEncode(-1);) 2025.06.13 15:46:39.960256 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function tryIdnaEncode: In scope SELECT tryIdnaEncode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:40.160110 [ 5978 ] {3b83fd10-6c47-4552-b249-af019b2b898c} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function tryPunycodeDecode: In scope SELECT tryPunycodeDecode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1525, line 1528) (in query: SELECT tryPunycodeDecode(-1);) 2025.06.13 15:46:40.182117 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function tryPunycodeDecode: In scope SELECT tryPunycodeDecode(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:40.327229 [ 5978 ] {47e390e0-c640-4435-b4bd-c069250aca31} executeQuery: Code: 42. DB::Exception: Number of arguments for function tumble doesn't match: passed 1, should be 2 or 3: In scope SELECT tumble(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1526, line 1529) (in query: SELECT tumble(-1);) 2025.06.13 15:46:40.363575 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tumble doesn't match: passed 1, should be 2 or 3: In scope SELECT tumble(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:40.394256 [ 5163 ] {b33e9366-3d5d-4520-89f3-17850ee681b7} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC')). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49966) (comment: 02507_to_unix_timestamp_overflow.sql) (query 1, line 1) (in query: SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl(DB::DateTime64 const&, unsigned int, unsigned int&) @ 0x000000002c4a45ee 6. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>(T::FieldType const&, unsigned int) @ 0x000000002c4ac659 7. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUnixTimestamp, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b22bf5f 8. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b2259a6 9. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, 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::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02e6b7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b067c1e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b066a83 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:46:40.413623 [ 5163 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC')). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl(DB::DateTime64 const&, unsigned int, unsigned int&) @ 0x000000002c4a45ee 6. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>(T::FieldType const&, unsigned int) @ 0x000000002c4ac659 7. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUnixTimestamp, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b22bf5f 8. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b2259a6 9. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, 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::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02e6b7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b067c1e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b066a83 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:46:40.564236 [ 5978 ] {adbc6c4e-e609-4bba-8a6b-7d6b1bb525ef} executeQuery: Code: 44. DB::Exception: Illegal type of first argument of function tumbleEnd should be DateTime, Tuple or UInt32: In scope SELECT tumbleEnd(-1). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1527, line 1530) (in query: SELECT tumbleEnd(-1);) 2025.06.13 15:46:40.599427 [ 5978 ] {} TCPHandler: Code: 44. DB::Exception: Illegal type of first argument of function tumbleEnd should be DateTime, Tuple or UInt32: In scope SELECT tumbleEnd(-1). (ILLEGAL_COLUMN) 2025.06.13 15:46:40.668841 [ 5978 ] {d9ad3cd2-9816-4829-bb0f-eb2a99018b8b} executeQuery: Code: 44. DB::Exception: Illegal type of first argument of function tumbleStart should be DateTime, Tuple or UInt32: In scope SELECT tumbleStart(-1). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1528, line 1531) (in query: SELECT tumbleStart(-1);) 2025.06.13 15:46:40.701747 [ 5978 ] {} TCPHandler: Code: 44. DB::Exception: Illegal type of first argument of function tumbleStart should be DateTime, Tuple or UInt32: In scope SELECT tumbleStart(-1). (ILLEGAL_COLUMN) 2025.06.13 15:46:40.927505 [ 8432 ] {7120bc2e-06fb-4868-823d-cada13bfde84} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49984) (comment: 03252_merge_tree_min_bytes_to_seek.sql) (query 3, line 7) (in query: CREATE TABLE t_min_bytes_to_seek (`id` UInt64) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 128, index_granularity_bytes = '1M', min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 500158482, compact_parts_max_bytes_to_buffer = 9670753, compact_parts_max_granules_to_buffer = 95, compact_parts_merge_max_bytes_to_prefetch_part = 28303772, merge_max_block_size = 9084, old_parts_lifetime = 120., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 330248, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 83, 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 = 24369, primary_key_compress_block_size = 59586, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:40.939458 [ 8432 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:41.048276 [ 5978 ] {71f8d2bd-51f7-4637-9469-6eccf56d1c84} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function tupleConcat: In scope SELECT tupleConcat(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1530, line 1533) (in query: SELECT tupleConcat(-1);) 2025.06.13 15:46:41.086114 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument 1 of function tupleConcat: In scope SELECT tupleConcat(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:41.195692 [ 5978 ] {83f6f397-bf9f-480f-86e0-08b4bdc8aac1} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 1, should be 2: In scope SELECT tupleDivide(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1531, line 1534) (in query: SELECT tupleDivide(-1);) 2025.06.13 15:46:41.199380 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 1, should be 2: In scope SELECT tupleDivide(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:41.289456 [ 5978 ] {9f11742e-20e7-4db4-bb4a-b10c0dee71b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleDivideByNumber(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1532, line 1535) (in query: SELECT tupleDivideByNumber(-1);) 2025.06.13 15:46:41.330156 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleDivideByNumber(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:41.363046 [ 5163 ] {a0fa4da6-192e-46bf-811b-54dbdb5262e4} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50014) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:41.383969 [ 5163 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:41.407149 [ 5978 ] {a247a124-cabd-44ea-9d1a-99549d0ce5dd} 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(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1533, line 1536) (in query: SELECT tupleElement(-1);) 2025.06.13 15:46:41.423522 [ 5978 ] {} 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(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:41.646055 [ 5978 ] {170271c6-cb1a-4a3e-808a-c6fc24cd05b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 1, should be 2: In scope SELECT tupleHammingDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1534, line 1537) (in query: SELECT tupleHammingDistance(-1);) 2025.06.13 15:46:41.651344 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 1, should be 2: In scope SELECT tupleHammingDistance(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:41.723599 [ 5978 ] {abf617c6-e377-4d81-ac24-1d988d3f7f02} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 1, should be 2: In scope SELECT tupleIntDiv(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1535, line 1538) (in query: SELECT tupleIntDiv(-1);) 2025.06.13 15:46:41.728233 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 1, should be 2: In scope SELECT tupleIntDiv(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:41.799448 [ 5978 ] {86f4612c-c87f-48d8-927c-87688bf972c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleIntDivByNumber(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1536, line 1539) (in query: SELECT tupleIntDivByNumber(-1);) 2025.06.13 15:46:41.820919 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleIntDivByNumber(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:41.895020 [ 5978 ] {270ef9e5-835e-4ba7-99da-9bb677bdc89b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 1, should be 2: In scope SELECT tupleIntDivOrZero(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1537, line 1540) (in query: SELECT tupleIntDivOrZero(-1);) 2025.06.13 15:46:41.915959 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 1, should be 2: In scope SELECT tupleIntDivOrZero(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:42.043293 [ 5978 ] {8496db47-2300-401d-a1c2-19fd185460df} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1538, line 1541) (in query: SELECT tupleIntDivOrZeroByNumber(-1);) 2025.06.13 15:46:42.080313 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:42.204565 [ 5978 ] {5deff61a-8329-4edf-a193-a13368dd532c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 1, should be 2: In scope SELECT tupleMinus(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1539, line 1542) (in query: SELECT tupleMinus(-1);) 2025.06.13 15:46:42.223694 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 1, should be 2: In scope SELECT tupleMinus(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:42.334881 [ 5978 ] {1716b009-5a25-4400-af62-fe2121c1c9e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 1, should be 2: In scope SELECT tupleModulo(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1540, line 1543) (in query: SELECT tupleModulo(-1);) 2025.06.13 15:46:42.341178 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 1, should be 2: In scope SELECT tupleModulo(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:42.457813 [ 5978 ] {40a7d10d-ca66-48eb-94b1-848f2b259153} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleModuloByNumber(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1541, line 1544) (in query: SELECT tupleModuloByNumber(-1);) 2025.06.13 15:46:42.474963 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleModuloByNumber(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:42.580893 [ 5978 ] {9ca58963-66b0-4d30-bd10-dd0d0568b11f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 1, should be 2: In scope SELECT tupleMultiply(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1542, line 1545) (in query: SELECT tupleMultiply(-1);) 2025.06.13 15:46:42.596103 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 1, should be 2: In scope SELECT tupleMultiply(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:42.755220 [ 5978 ] {c2120454-6b32-4abf-81f3-ed62ca5fd86d} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleMultiplyByNumber(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1543, line 1546) (in query: SELECT tupleMultiplyByNumber(-1);) 2025.06.13 15:46:42.769077 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 1, should be 2: In scope SELECT tupleMultiplyByNumber(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:42.895262 [ 5005 ] {acbd6915-4858-4fb1-9247-fdbc690c7871} executeQuery: Code: 714. DB::Exception: `cluster_for_parallel_replicas` setting refers to cluster with 2 shards. Expected a cluster with one shard. (UNEXPECTED_CLUSTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50056) (comment: 02982_parallel_replicas_unexpected_cluster.sql) (query 6, line 8) (in query: SELECT count() FROM test_unexpected_cluster WHERE NOT ignore(*);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x0000000019d384af 5. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:853: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x000000002f9cf52f 6. ./build_docker/./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) @ 0x000000002dda12d9 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 8. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:42.928587 [ 5005 ] {} TCPHandler: Code: 714. DB::Exception: `cluster_for_parallel_replicas` setting refers to cluster with 2 shards. Expected a cluster with one shard. (UNEXPECTED_CLUSTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x0000000019d384af 5. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:853: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x000000002f9cf52f 6. ./build_docker/./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) @ 0x000000002dda12d9 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 8. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 9. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:42.942787 [ 5978 ] {938836de-74bb-4d28-8197-af241395a80a} executeQuery: Code: 43. DB::Exception: First argument for function tupleNames must be a tuple: In scope SELECT tupleNames(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1544, line 1547) (in query: SELECT tupleNames(-1);) 2025.06.13 15:46:42.967395 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleNames must be a tuple: In scope SELECT tupleNames(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:43.051855 [ 5978 ] {5cae45fd-acb1-4d18-987f-31f44baa249d} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleNegate should be tuple, got Int8: In scope SELECT tupleNegate(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1545, line 1548) (in query: SELECT tupleNegate(-1);) 2025.06.13 15:46:43.074578 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleNegate should be tuple, got Int8: In scope SELECT tupleNegate(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:43.147433 [ 5978 ] {37b9e733-e552-4168-aa62-6d911c527513} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 1, should be 2: In scope SELECT tuplePlus(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1546, line 1549) (in query: SELECT tuplePlus(-1);) 2025.06.13 15:46:43.173298 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 1, should be 2: In scope SELECT tuplePlus(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:43.216222 [ 8099 ] {730420cf-bd39-411b-a5b0-4b3295e1f8f8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=879, jobs=843). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49932) (comment: 02489_analyzer_indexes.sql) (query 12, line 31) (in query: SELECT count() FROM test_table WHERE id = 1 AND value_3 = '1' SETTINGS force_primary_key = 1, force_data_skipping_indices = 'value_3_idx';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:46:43.254956 [ 8099 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=879, jobs=843). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:46:43.275608 [ 5978 ] {6d96d17e-e53a-4ebc-8636-25e0bcc64ba3} executeQuery: Code: 43. DB::Exception: First argument for function tupleToNameValuePairs must be a tuple.: In scope SELECT tupleToNameValuePairs(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1547, line 1550) (in query: SELECT tupleToNameValuePairs(-1);) 2025.06.13 15:46:43.291643 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleToNameValuePairs must be a tuple.: In scope SELECT tupleToNameValuePairs(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:43.406803 [ 5978 ] {637d9d51-942c-4c3a-b439-fa2fa3badff8} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function upper: In scope SELECT ucase(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1548, line 1551) (in query: SELECT ucase(-1);) 2025.06.13 15:46:43.415472 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function upper: In scope SELECT ucase(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:43.519815 [ 5978 ] {d1011b22-32f6-448e-b79d-4bf78e61380d} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function unbin: In scope SELECT unbin(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1549, line 1552) (in query: SELECT unbin(-1);) 2025.06.13 15:46:43.530034 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function unbin: In scope SELECT unbin(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:43.628658 [ 5978 ] {7b20aeef-96b1-40d0-bd67-1aee0f9ef803} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function unhex: In scope SELECT unhex(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1550, line 1553) (in query: SELECT unhex(-1);) 2025.06.13 15:46:43.642778 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function unhex: In scope SELECT unhex(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:44.012294 [ 5112 ] {0d79168d-4429-4995-bde7-dbd069d7d1f7} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41486) (comment: 02519_monotonicity_fuzz.sql) (query 2, line 2) (in query: CREATE TABLE t (`x` Decimal(18, 3)) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 16979, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 53, min_bytes_for_full_part_storage = 338225204, compact_parts_max_bytes_to_buffer = 348007324, compact_parts_max_granules_to_buffer = 193, compact_parts_merge_max_bytes_to_prefetch_part = 19321747, merge_max_block_size = 10914, old_parts_lifetime = 215., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 63, min_merge_bytes_to_use_direct_io = 9890226376, index_granularity_bytes = 29660044, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 13, 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 = 85076, primary_key_compress_block_size = 51573, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:44.041217 [ 5112 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:44.856164 [ 5978 ] {5d846fd5-d619-4cdf-b1a1-476e14502fca} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 1, should be 2: In scope SELECT uniqThetaIntersect(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1557, line 1560) (in query: SELECT uniqThetaIntersect(-1);) 2025.06.13 15:46:44.864813 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 1, should be 2: In scope SELECT uniqThetaIntersect(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:44.983595 [ 3821 ] {2d94d5b2-4797-4c6c-870f-cd3b447627b1} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41532) (comment: 01030_incorrect_count_summing_merge_tree.sql) (query 4, line 6) (in query: CREATE TABLE tst (`timestamp` DateTime, `val` Nullable(Int8)) ENGINE = SummingMergeTree PARTITION BY toYYYYMM(timestamp) ORDER BY timestamp SETTINGS index_granularity = 35479, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 3973515, compact_parts_max_bytes_to_buffer = 533226447, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 19725862, merge_max_block_size = 7057, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 140065, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 28032962, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 66, 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 = 34698, primary_key_compress_block_size = 55091, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:44.984017 [ 5978 ] {45f64409-cfc8-4a73-9ab0-e4e1b4c27a44} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 1, should be 2: In scope SELECT uniqThetaNot(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1558, line 1561) (in query: SELECT uniqThetaNot(-1);) 2025.06.13 15:46:45.015919 [ 3821 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:45.024516 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 1, should be 2: In scope SELECT uniqThetaNot(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:45.230001 [ 5978 ] {c2cba4ee-afcd-4692-b5d5-42799835579b} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 1, should be 2: In scope SELECT uniqThetaUnion(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1559, line 1562) (in query: SELECT uniqThetaUnion(-1);) 2025.06.13 15:46:45.234750 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 1, should be 2: In scope SELECT uniqThetaUnion(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:45.308094 [ 8430 ] {ab355215-a76e-4c1e-8a69-14e402d0f32f} executeQuery: Code: 117. DB::Exception: Index 2 in Dictionary column is out of bounds, dictionary size is 2: (in file/uri /var/lib/clickhouse/user_files/test-02383-15953-25749/corrupted.arrow): While executing ArrowBlockInputFormat: While executing File. (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41576) (comment: 02383_arrow_dict_special_cases.sh) (query 1, line 1) (in query: select * from file('/var/lib/clickhouse/user_files/test-02383-15953-25749/corrupted.arrow')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, long&&, unsigned long&&) @ 0x00000000318acb6f 5. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:571: DB::ColumnWithTypeAndName DB::readColumnWithIndexesDataImpl>(std::shared_ptr&, String const&, long, char8_t, bool) @ 0x000000003189e44b 6. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:656: DB::readNonNullableColumnFromArrowColumn(std::shared_ptr const&, String, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr, bool, DB::ReadColumnFromArrowColumnSettings const&) @ 0x00000000318853e8 7. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:1241: DB::readColumnFromArrowColumn(std::shared_ptr const&, String, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr, bool, bool, DB::ReadColumnFromArrowColumnSettings const&) @ 0x0000000031872295 8. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:1446: DB::ArrowColumnToCHColumn::arrowColumnsToCHChunk(std::unordered_map, std::equal_to, std::allocator>> const&, unsigned long, DB::BlockMissingValues*) @ 0x0000000031873bd2 9. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:1351: DB::ArrowColumnToCHColumn::arrowTableToCHChunk(std::shared_ptr const&, unsigned long, DB::BlockMissingValues*) @ 0x00000000318732a3 10. ./build_docker/./src/Processors/Formats/Impl/ArrowBlockInputFormat.cpp:92: DB::ArrowBlockInputFormat::read() @ 0x0000000031857492 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:46:45.356677 [ 8430 ] {} TCPHandler: Code: 117. DB::Exception: Index 2 in Dictionary column is out of bounds, dictionary size is 2: (in file/uri /var/lib/clickhouse/user_files/test-02383-15953-25749/corrupted.arrow): While executing ArrowBlockInputFormat: While executing File. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, long&&, unsigned long&&) @ 0x00000000318acb6f 5. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:571: DB::ColumnWithTypeAndName DB::readColumnWithIndexesDataImpl>(std::shared_ptr&, String const&, long, char8_t, bool) @ 0x000000003189e44b 6. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:656: DB::readNonNullableColumnFromArrowColumn(std::shared_ptr const&, String, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr, bool, DB::ReadColumnFromArrowColumnSettings const&) @ 0x00000000318853e8 7. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:1241: DB::readColumnFromArrowColumn(std::shared_ptr const&, String, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr, bool, bool, DB::ReadColumnFromArrowColumnSettings const&) @ 0x0000000031872295 8. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:1446: DB::ArrowColumnToCHColumn::arrowColumnsToCHChunk(std::unordered_map, std::equal_to, std::allocator>> const&, unsigned long, DB::BlockMissingValues*) @ 0x0000000031873bd2 9. ./build_docker/./src/Processors/Formats/Impl/ArrowColumnToCHColumn.cpp:1351: DB::ArrowColumnToCHColumn::arrowTableToCHChunk(std::shared_ptr const&, unsigned long, DB::BlockMissingValues*) @ 0x00000000318732a3 10. ./build_docker/./src/Processors/Formats/Impl/ArrowBlockInputFormat.cpp:92: DB::ArrowBlockInputFormat::read() @ 0x0000000031857492 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:46:45.536399 [ 5978 ] {34cd48f9-c6a4-4a71-8733-a50a32347cb7} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function upper: In scope SELECT upper(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1561, line 1564) (in query: SELECT upper(-1);) 2025.06.13 15:46:45.573716 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function upper: In scope SELECT upper(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:45.648957 [ 5978 ] {2381680b-d107-4ab9-98f3-8f1258ec970c} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function upperUTF8: In scope SELECT upperUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1562, line 1565) (in query: SELECT upperUTF8(-1);) 2025.06.13 15:46:45.663264 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function upperUTF8: In scope SELECT upperUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:45.751533 [ 5978 ] {fc7445a2-258a-4ff6-9504-d2e81e7faa9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 1, should be 0: In scope SELECT uptime(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1563, line 1566) (in query: SELECT uptime(-1);) 2025.06.13 15:46:45.769109 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 1, should be 0: In scope SELECT uptime(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:45.908103 [ 5978 ] {12bdfc19-0faf-4648-81d3-b3c8a10f15e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 1, should be 0: In scope SELECT user(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1564, line 1567) (in query: SELECT user(-1);) 2025.06.13 15:46:45.923043 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 1, should be 0: In scope SELECT user(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:46.068302 [ 5978 ] {22f44edf-9355-4f88-b69a-05ff8c0bfeb0} executeQuery: Code: 42. DB::Exception: Function validateNestedArraySizes needs more than two arguments; passed 1.: In scope SELECT validateNestedArraySizes(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1565, line 1568) (in query: SELECT validateNestedArraySizes(-1);) 2025.06.13 15:46:46.093789 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Function validateNestedArraySizes needs more than two arguments; passed 1.: In scope SELECT validateNestedArraySizes(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:46.105015 [ 5110 ] {c24cd4f9-b127-47db-88f2-d7641ed17910} executeQuery: Code: 81. DB::Exception: Database nonexistent does not exist. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40790) (comment: 03319_http_exception_formatting_during_interpretation.sh) (in query: SELECT * FROM nonexistent.nonexistent FORMAT JSONLines), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5eea3e 6. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002d4aafbf 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000002d1345d3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1e5f4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4cbc1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 21. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 22. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 23. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:46:46.129863 [ 5110 ] {c24cd4f9-b127-47db-88f2-d7641ed17910} DynamicQueryHandler: Code: 81. DB::Exception: Database nonexistent does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:678: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5eea3e 6. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002d4aafbf 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000002d1345d3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1e5f4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4cbc1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 21. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 22. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 23. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:46.398730 [ 18510 ] {cccf5644-8946-40b4-a130-b19fa6d45888} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41690) (comment: 00763_lock_buffer_long.sh) (query 1, line 1) (in query: CREATE TABLE buffer_00763_2 (s String) ENGINE = Buffer('test_7', mt_00763_2, 1, 1, 1, 1, 1, 1, 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:46.413630 [ 18510 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002c7f6311 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2001: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7ea70 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:46.904979 [ 5978 ] {fffb1ecb-8d87-43a1-ace4-a008753f37a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantElement doesn't match: passed 1, should be 2 or 3: In scope SELECT variantElement(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1570, line 1573) (in query: SELECT variantElement(-1);) 2025.06.13 15:46:46.914490 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantElement doesn't match: passed 1, should be 2 or 3: In scope SELECT variantElement(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:47.130356 [ 5978 ] {4bbb164a-7b14-4786-9373-c95e84a54daa} executeQuery: Code: 43. DB::Exception: First argument for function variantType must be Variant, got Int8 instead: In scope SELECT variantType(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1571, line 1574) (in query: SELECT variantType(-1);) 2025.06.13 15:46:47.145791 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function variantType must be Variant, got Int8 instead: In scope SELECT variantType(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:47.171780 [ 3894 ] {926f6996-cfe4-479f-8bf0-4cf37f37ef4a} executeQuery: Code: 219. DB::Exception: Cannot drop: Cannot remove directory /var/lib/clickhouse/data/test_7/: , errno: 39, strerror: Directory not empty. Probably database contain some detached tables or metadata leftovers from Ordinary engine. If you want to remove all data anyway, try to attach database back and drop it again with enabled force_remove_data_recursively_on_drop setting. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41730) (comment: 03088_analyzer_ambiguous_column_multi_call.sql) (query 2, line 4) (in query: DROP DATABASE IF EXISTS test_7), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:611: DB::DatabaseOnDisk::drop(std::shared_ptr) @ 0x000000002c7277c5 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:627: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed1f6 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:47.216744 [ 3894 ] {} TCPHandler: Code: 219. DB::Exception: Cannot drop: Cannot remove directory /var/lib/clickhouse/data/test_7/: , errno: 39, strerror: Directory not empty. Probably database contain some detached tables or metadata leftovers from Ordinary engine. If you want to remove all data anyway, try to attach database back and drop it again with enabled force_remove_data_recursively_on_drop setting. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000001cbdeb8f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:611: DB::DatabaseOnDisk::drop(std::shared_ptr) @ 0x000000002c7277c5 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:627: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed1f6 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:47.315238 [ 5978 ] {4d84ece7-b87f-42ac-b860-8613869649b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 1, should be 2: In scope SELECT vectorDifference(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1572, line 1575) (in query: SELECT vectorDifference(-1);) 2025.06.13 15:46:47.358417 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 1, should be 2: In scope SELECT vectorDifference(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:47.447411 [ 5978 ] {115ca53e-8f6f-437e-9212-9817b2c83f46} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 1, should be 2: In scope SELECT vectorSum(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1573, line 1576) (in query: SELECT vectorSum(-1);) 2025.06.13 15:46:47.453394 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 1, should be 2: In scope SELECT vectorSum(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:47.474240 [ 4171 ] {03721429-23ac-4f45-ab93-7948cad947ca} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41748) (comment: 02459_group_by_all.sql) (query 2, line 3) (in query: CREATE TABLE group_by_all ( a String, b int, c int ) engine = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:47.484334 [ 4171 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:47.529414 [ 5978 ] {a63a021b-c49c-45eb-b281-c3698758402d} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 1, should be 0: In scope SELECT version(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1574, line 1577) (in query: SELECT version(-1);) 2025.06.13 15:46:47.540196 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 1, should be 0: In scope SELECT version(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:47.672737 [ 4171 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:47.679919 [ 4171 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:47.799566 [ 5978 ] {10c47178-ef35-4f16-9a33-96c61994447a} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractBool(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1576, line 1579) (in query: SELECT visitParamExtractBool(-1);) 2025.06.13 15:46:47.812650 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractBool(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:47.947228 [ 5978 ] {98346d43-416d-4214-94a0-83500a4392d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractFloat(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1577, line 1580) (in query: SELECT visitParamExtractFloat(-1);) 2025.06.13 15:46:47.966175 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractFloat(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:48.005637 [ 8099 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:48.010003 [ 8099 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:48.104340 [ 5978 ] {18bf1e4d-1785-4309-9922-84921e0096b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractInt(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1578, line 1581) (in query: SELECT visitParamExtractInt(-1);) 2025.06.13 15:46:48.143933 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractInt(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:48.197027 [ 5978 ] {f710835d-9ec1-404d-93c4-3d1e5795761a} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractRaw(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1579, line 1582) (in query: SELECT visitParamExtractRaw(-1);) 2025.06.13 15:46:48.197052 [ 6234 ] {6068b5c2-3e09-4c2c-afa7-739c3ad5f8bb} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41846) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: CREATE TABLE msgpack (uint8 UInt8, uint16 UInt16, uint32 UInt32, uint64 UInt64, int8 Int8, int16 Int16, int32 Int32, int64 Int64, float Float32, double Float64, string String, date Date, datetime DateTime('Asia/Istanbul'), datetime64 DateTime64(3, 'Asia/Istanbul'), array Array(UInt32)) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:48.203998 [ 6234 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:48.224115 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractRaw(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:48.419325 [ 5978 ] {10685d43-dec1-4f0f-b417-fb6ee0779c9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractString(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1580, line 1583) (in query: SELECT visitParamExtractString(-1);) 2025.06.13 15:46:48.462374 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractString(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:48.472419 [ 6234 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:48.473630 [ 6234 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:48.591218 [ 5978 ] {0c638bd8-13b2-4c41-adef-6aa8369b0929} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractUInt(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1581, line 1584) (in query: SELECT visitParamExtractUInt(-1);) 2025.06.13 15:46:48.597520 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 1, should be 2: In scope SELECT visitParamExtractUInt(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:48.762770 [ 5978 ] {f9dfe8da-5bee-4d15-a006-db86d72f8d08} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 1, should be 2: In scope SELECT visitParamHas(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1582, line 1585) (in query: SELECT visitParamHas(-1);) 2025.06.13 15:46:48.880680 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 1, should be 2: In scope SELECT visitParamHas(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:49.262862 [ 5978 ] {185b3915-f495-4cfc-bf10-eab9e7ad9a8c} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT week(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1583, line 1586) (in query: SELECT week(-1);) 2025.06.13 15:46:49.380231 [ 9636 ] {a2516cf0-48ed-45e4-9bf3-1f27ff3cad47} executeQuery: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41888) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: INSERT INTO msgpack VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:49.380318 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT week(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:49.460251 [ 9636 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:49.832076 [ 5978 ] {dbbebc6a-4950-4039-87e0-e0d47e72e626} executeQuery: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1584, line 1587) (in query: SELECT welchTTest(-1);) 2025.06.13 15:46:49.836018 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:50.165844 [ 5978 ] {b0c2e245-1236-4c2f-ac27-85177646d7de} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 1, should be 4: In scope SELECT widthBucket(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1585, line 1588) (in query: SELECT widthBucket(-1);) 2025.06.13 15:46:50.173219 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 1, should be 4: In scope SELECT widthBucket(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:50.467932 [ 5978 ] {04ef6608-eb27-4c68-a66a-7ac98c376042} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 1, should be 4: In scope SELECT width_bucket(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1586, line 1589) (in query: SELECT width_bucket(-1);) 2025.06.13 15:46:50.474171 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 1, should be 4: In scope SELECT width_bucket(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:50.680831 [ 5163 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:50.705621 [ 5163 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:51.039719 [ 5978 ] {421ada5f-2a48-41bd-b22b-409d1e4dffbe} executeQuery: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1587, line 1590) (in query: SELECT windowFunnel(-1);) 2025.06.13 15:46:51.046172 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:51.340511 [ 5978 ] {b7c89468-8ffe-442d-9260-91211729b7da} executeQuery: Code: 42. DB::Exception: Number of arguments for function windowID doesn't match: passed 1, should be 2, 3 or 4: In scope SELECT windowID(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1588, line 1591) (in query: SELECT windowID(-1);) 2025.06.13 15:46:51.372613 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function windowID doesn't match: passed 1, should be 2, 3 or 4: In scope SELECT windowID(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:51.713417 [ 5978 ] {43626f10-43ed-4295-946d-674e29acafca} executeQuery: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT wkt(-1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1589, line 1592) (in query: SELECT wkt(-1);) 2025.06.13 15:46:51.737628 [ 5978 ] {} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Int8: In scope SELECT wkt(-1). (BAD_ARGUMENTS) 2025.06.13 15:46:51.834327 [ 34370 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:51.841088 [ 34370 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:52.005244 [ 5978 ] {9713153e-2bac-49ad-bd7e-a04a2ad6bd74} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHash must be String, got Int8: In scope SELECT wordShingleMinHash(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1590, line 1593) (in query: SELECT wordShingleMinHash(-1);) 2025.06.13 15:46:52.014231 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHash must be String, got Int8: In scope SELECT wordShingleMinHash(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:52.056836 [ 3894 ] {3bd70afa-c3a8-4fdd-a973-7c9a164dd481} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51518) (comment: 01391_join_on_dict_crash.sql) (in query: DROP DATABASE IF EXISTS test_0dlmx5th SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:52.105671 [ 3894 ] {3bd70afa-c3a8-4fdd-a973-7c9a164dd481} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:52.202818 [ 18511 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:52.210659 [ 18511 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:52.210997 [ 5978 ] {3454b09c-f993-4125-9446-89ffc3d6c5ea} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArg must be String, got Int8: In scope SELECT wordShingleMinHashArg(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1591, line 1594) (in query: SELECT wordShingleMinHashArg(-1);) 2025.06.13 15:46:52.224223 [ 7755 ] {3f1085ca-718e-4314-b61e-850d602c6fed} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack' in scope SELECT * FROM msgpack. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42406) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM msgpack FORMAT MsgPack), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:52.229318 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArg must be String, got Int8: In scope SELECT wordShingleMinHashArg(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:52.245126 [ 7755 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack' in scope SELECT * FROM msgpack. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:52.319916 [ 5978 ] {203c2520-6f77-4f9c-bd2e-ba9d63fcfdcc} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitive must be String, got Int8: In scope SELECT wordShingleMinHashArgCaseInsensitive(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1592, line 1595) (in query: SELECT wordShingleMinHashArgCaseInsensitive(-1);) 2025.06.13 15:46:52.342268 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitive must be String, got Int8: In scope SELECT wordShingleMinHashArgCaseInsensitive(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:52.379007 [ 3895 ] {e08beb31-ce0f-482d-a68e-b1a6c71c1104} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51534) (comment: 01391_join_on_dict_crash.sql) (in query: DROP DATABASE IF EXISTS test_0dlmx5th SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:52.381571 [ 3509 ] {1ad12726-b340-4c3a-aeb6-5376ac3946d0::all_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:52.383043 [ 3895 ] {e08beb31-ce0f-482d-a68e-b1a6c71c1104} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:52.403200 [ 3509 ] {1ad12726-b340-4c3a-aeb6-5376ac3946d0::all_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:52.406727 [ 3509 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ad12726-b340-4c3a-aeb6-5376ac3946d0::all_1_1_0_3}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:52.448279 [ 5112 ] {e608605b-4975-4c86-a8e3-e026b60f7ba6} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_1_1_0_2' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 . (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:41796) (comment: 03096_update_non_indexed_columns.sql) (query 8, line 27) (in query: alter table test_03096 update b = 123 where c = 0 SETTINGS mutations_sync=2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:52.479480 [ 5978 ] {611234e9-b3e2-4b9d-9312-6d1b8701f875} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitiveUTF8 must be String, got Int8: In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1593, line 1596) (in query: SELECT wordShingleMinHashArgCaseInsensitiveUTF8(-1);) 2025.06.13 15:46:52.490131 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitiveUTF8 must be String, got Int8: In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:52.495073 [ 5112 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_1_1_0_2' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:46:52.499692 [ 4107 ] {be159cb6-e470-45b1-a5e3-db41a7556e70} 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.20286.altinityantalya (altinity build)) (from [::1]:42276) (comment: 02449_check_dependencies_and_table_shutdown.sql) (query 4, line 5) (in query: CREATE TABLE view (id UInt32, value String) ENGINE=ReplicatedMergeTree('/test/2449/{database}', '1') ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:52.556315 [ 4107 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:52.656213 [ 9642 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:52.663999 [ 9642 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:52.683332 [ 5978 ] {6856e96c-7f01-476a-bf79-20346e372ae9} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgUTF8 must be String, got Int8: In scope SELECT wordShingleMinHashArgUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1594, line 1597) (in query: SELECT wordShingleMinHashArgUTF8(-1);) 2025.06.13 15:46:52.724304 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgUTF8 must be String, got Int8: In scope SELECT wordShingleMinHashArgUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:53.035469 [ 5978 ] {e45b9508-8467-4126-b143-df1c68fd143c} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitive must be String, got Int8: In scope SELECT wordShingleMinHashCaseInsensitive(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1595, line 1598) (in query: SELECT wordShingleMinHashCaseInsensitive(-1);) 2025.06.13 15:46:53.053254 [ 8430 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:53.054227 [ 8430 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:53.068494 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitive must be String, got Int8: In scope SELECT wordShingleMinHashCaseInsensitive(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:53.194015 [ 5978 ] {dcbbbd33-d85e-4879-a7db-5994ed718451} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitiveUTF8 must be String, got Int8: In scope SELECT wordShingleMinHashCaseInsensitiveUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1596, line 1599) (in query: SELECT wordShingleMinHashCaseInsensitiveUTF8(-1);) 2025.06.13 15:46:53.222141 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitiveUTF8 must be String, got Int8: In scope SELECT wordShingleMinHashCaseInsensitiveUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:53.329042 [ 5978 ] {78dc1976-6178-426e-9f52-31c1875bca58} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashUTF8 must be String, got Int8: In scope SELECT wordShingleMinHashUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1597, line 1600) (in query: SELECT wordShingleMinHashUTF8(-1);) 2025.06.13 15:46:53.347057 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashUTF8 must be String, got Int8: In scope SELECT wordShingleMinHashUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:53.363034 [ 7279 ] {c6dd0c08-6dc9-4a25-be53-207945f16d31} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 1.00 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42500) (comment: 02400_memory_accounting_on_error.sql) (query 1, line 1) (in query: -- max_block_size to avoid randomization SELECT * FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536 SETTINGS max_memory_usage='1Gi', max_block_size=65505, log_queries=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:53.391075 [ 7279 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 1.00 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:46:53.406224 [ 8430 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:53.411656 [ 8430 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:53.468335 [ 9642 ] {1856e31b-b223-4f7b-a2be-25f7f20ca2eb} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack' in scope SELECT * FROM msgpack. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42142) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM msgpack), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:53.481360 [ 5978 ] {a3974a43-1842-4eaf-be3c-3f8e73a80dc8} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHash must be String, got Int8: In scope SELECT wordShingleSimHash(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1598, line 1601) (in query: SELECT wordShingleSimHash(-1);) 2025.06.13 15:46:53.491041 [ 9642 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack' in scope SELECT * FROM msgpack. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:53.518638 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHash must be String, got Int8: In scope SELECT wordShingleSimHash(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:53.705727 [ 5978 ] {7712bbba-c391-4d5d-a166-446e72f91b26} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitive must be String, got Int8: In scope SELECT wordShingleSimHashCaseInsensitive(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1599, line 1602) (in query: SELECT wordShingleSimHashCaseInsensitive(-1);) 2025.06.13 15:46:53.711415 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitive must be String, got Int8: In scope SELECT wordShingleSimHashCaseInsensitive(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:53.757811 [ 5978 ] {a581a93c-13da-42c5-bbb4-7f4e56c1dc8d} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitiveUTF8 must be String, got Int8: In scope SELECT wordShingleSimHashCaseInsensitiveUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1600, line 1603) (in query: SELECT wordShingleSimHashCaseInsensitiveUTF8(-1);) 2025.06.13 15:46:53.768569 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitiveUTF8 must be String, got Int8: In scope SELECT wordShingleSimHashCaseInsensitiveUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:53.945581 [ 5978 ] {aa589ed3-998a-46a4-8bfb-7eb549551d85} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashUTF8 must be String, got Int8: In scope SELECT wordShingleSimHashUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1601, line 1604) (in query: SELECT wordShingleSimHashUTF8(-1);) 2025.06.13 15:46:53.956023 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashUTF8 must be String, got Int8: In scope SELECT wordShingleSimHashUTF8(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:54.144538 [ 18602 ] {cb3058ca-3849-4056-862e-6fea1ea78c52} executeQuery: Code: 36. DB::Exception: Element of set in IN, VALUES, or LIMIT, or aggregate function parameter, or a table function argument is not a constant expression (result column not found): cityHash64(globalIn(materialize(0), (NULL, -2147483648, -9223372036854775808)), nan, 1024, _CAST(NULL, 'Nullable(Nothing)'), materialize(1.000100016593933), 0, _CAST(NULL, 'Nullable(Nothing)')). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42170) (comment: 03234_evaluate_constant_analyzer.sql) (query 1, line 1) (in query: SELECT count() FROM numbers(cityHash64(materialize(toLowCardinality(toNullable(0))) GLOBAL IN (NULL, -2147483648, -9223372036854775808), nan, 1024, NULL, materialize(1.000100016593933), 0, NULL), 4) AS n1, numbers(3) AS n2, numbers(6) AS n3 GROUP BY (NULL, cityHash64(inf, -2147483648, toLowCardinality(16), NULL, 10.000100135803223), cityHash64(1.1754943508222875e-38, NULL, NULL, NULL), 2147483647), cityHash64(0., 3, NULL, NULL, 10000000000., NULL, NULL) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:171: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e26dbc7 6. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e26f0e7 7. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:102: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a2d50 8. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a2251 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 10. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5125: DB::QueryAnalyzer::resolveCrossJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc52acd 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5338: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc49 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:46:54.189936 [ 18602 ] {} TCPHandler: Code: 36. DB::Exception: Element of set in IN, VALUES, or LIMIT, or aggregate function parameter, or a table function argument is not a constant expression (result column not found): cityHash64(globalIn(materialize(0), (NULL, -2147483648, -9223372036854775808)), nan, 1024, _CAST(NULL, 'Nullable(Nothing)'), materialize(1.000100016593933), 0, _CAST(NULL, 'Nullable(Nothing)')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:171: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x000000002e26dbc7 6. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002e26f0e7 7. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:102: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a2d50 8. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000284a2251 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 10. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5125: DB::QueryAnalyzer::resolveCrossJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc52acd 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5338: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc49 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:46:54.290298 [ 3894 ] {3b775240-6efe-4abb-9fb0-4e2f10ed74df} executeQuery: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42228) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: DROP TABLE msgpack), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:46:54.312087 [ 3894 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:46:54.383020 [ 5978 ] {57c6646e-826b-4448-a0b1-e5e9f12c0f5e} executeQuery: Code: 35. DB::Exception: Number of arguments for function "xor" should be at least 2: passed 1: In scope SELECT xor(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1603, line 1606) (in query: SELECT xor(-1);) 2025.06.13 15:46:54.397547 [ 5978 ] {} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "xor" should be at least 2: passed 1: In scope SELECT xor(-1). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:46:54.869701 [ 5112 ] {d8759003-8f1e-44c1-82bc-57469ab950cf} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42212) (comment: 02477_fuse_quantiles.sql) (query 4, line 6) (in query: CREATE TABLE fuse_tbl(a Nullable(Int32), b Int32) Engine = Log;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:54.894636 [ 5112 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:54.991272 [ 18602 ] {07a4d552-d860-4df5-ac38-16df6187edef} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42232) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: CREATE TABLE msgpack (array1 Array(Array(UInt32)), array2 Array(Array(Array(String)))) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:55.006646 [ 18602 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:55.102377 [ 5978 ] {b2fc11a2-0834-4aa1-a8a7-d83f4d2a2d45} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 1, should be 2: In scope SELECT yandexConsistentHash(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1607, line 1610) (in query: SELECT yandexConsistentHash(-1);) 2025.06.13 15:46:55.120600 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 1, should be 2: In scope SELECT yandexConsistentHash(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:55.297221 [ 5978 ] {ee750df7-b5b0-4d07-997f-64d55bc3a8f5} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT yearweek(-1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1608, line 1611) (in query: SELECT yearweek(-1);) 2025.06.13 15:46:55.342935 [ 5978 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT yearweek(-1). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:46:55.514040 [ 5978 ] {2442713e-3fc1-4cfe-af19-641a5726611b} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 1, should be 0: In scope SELECT yesterday(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1609, line 1612) (in query: SELECT yesterday(-1);) 2025.06.13 15:46:55.521353 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 1, should be 0: In scope SELECT yesterday(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:55.600760 [ 18380 ] {1f65b390-afd9-4c0b-99ad-af5ebb1922e7} executeQuery: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42298) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: INSERT INTO msgpack VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:55.628671 [ 18380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:55.643847 [ 5978 ] {818f78da-341c-4c5b-b135-0b8e218a649d} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 1, should be 0: In scope SELECT zookeeperSessionUptime(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55776) (comment: 00534_functions_bad_arguments6.sh) (query 1610, line 1613) (in query: SELECT zookeeperSessionUptime(-1);) 2025.06.13 15:46:55.650726 [ 5978 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 1, should be 0: In scope SELECT zookeeperSessionUptime(-1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:46:55.996935 [ 4171 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:55.997801 [ 4171 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:56.098453 [ 4107 ] {b07e7947-5f07-451b-acc5-16e251fd9efc} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack' in scope SELECT * FROM msgpack. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42364) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM msgpack FORMAT MsgPack), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:56.132913 [ 4107 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack' in scope SELECT * FROM msgpack. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:56.311135 [ 18602 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:56.311876 [ 18602 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:56.653355 [ 3894 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:56.654737 [ 3894 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:57.017912 [ 6234 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:57.019188 [ 6234 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:57.053483 [ 3894 ] {594974e2-ed6f-4605-9851-0d89f5b5cf1b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack' in scope SELECT * FROM msgpack. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42432) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM msgpack), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:57.087382 [ 3894 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack' in scope SELECT * FROM msgpack. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:57.231098 [ 9636 ] {231d33b2-fa18-450e-a264-dc21d0878949} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42448) (comment: 01019_alter_materialized_view_consistent.sh) (query 1, line 1) (in query: DROP TABLE src_b), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:57.252182 [ 9636 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:46:57.368308 [ 18380 ] {6d86f0df-0062-420d-aa15-547050880711} executeQuery: Code: 36. DB::Exception: Floating point partition key is not supported: a. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42440) (comment: 01630_disallow_floating_point_as_partition_key.sql) (query 2, line 2) (in query: CREATE TABLE test (`a` Float32, `b` int) ENGINE = MergeTree PARTITION BY a ORDER BY tuple() SETTINGS index_granularity = 9175, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 44, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 397549302, compact_parts_max_granules_to_buffer = 231, compact_parts_merge_max_bytes_to_prefetch_part = 1906595, merge_max_block_size = 5294, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 9026542202, 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 = 760197, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 79339, primary_key_compress_block_size = 59850, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311be5d8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:57.377458 [ 18380 ] {} TCPHandler: Code: 36. DB::Exception: Floating point partition key is not supported: a. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311be5d8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:57.456330 [ 2860 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:57.457413 [ 2860 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:57.710565 [ 7755 ] {840e35ee-79e9-46d1-b98b-0cd03b72dcdc} executeQuery: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42482) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: DROP TABLE msgpack), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:46:57.737297 [ 7755 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:46:57.994837 [ 18380 ] {0723724f-d5ed-4208-877d-329a4788e242} executeQuery: Code: 36. DB::Exception: Floating point partition key is not supported: d. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42440) (comment: 01630_disallow_floating_point_as_partition_key.sql) (query 5, line 5) (in query: CREATE TABLE test (`a` Float32, `b` int, `c` String, `d` Float64) ENGINE = MergeTree PARTITION BY (b, c, d) ORDER BY tuple() SETTINGS allow_floating_point_partition_key = false, index_granularity = 9175, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 44, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 397549302, compact_parts_max_granules_to_buffer = 231, compact_parts_merge_max_bytes_to_prefetch_part = 1906595, merge_max_block_size = 5294, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 9026542202, 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 = 760197, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 79339, primary_key_compress_block_size = 59850, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311be5d8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:58.012369 [ 18380 ] {} TCPHandler: Code: 36. DB::Exception: Floating point partition key is not supported: d. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311be5d8 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:58.592950 [ 2860 ] {140d6863-dd9b-4372-a9c1-23d9f77c0d51} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42502) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: CREATE TABLE msgpack (array Array(UInt8)) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:58.606838 [ 2860 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:59.260055 [ 2860 ] {a9c89c4c-1334-42f6-bd64-c7387a450090} executeQuery: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42538) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: INSERT INTO msgpack VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:59.286299 [ 2860 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:59.879331 [ 5163 ] {34f94442-a144-4c62-9d6b-77416f88ba11} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42548) (comment: 01602_insert_into_table_function_cluster.sql) (query 3, line 4) (in query: CREATE TABLE x AS system.numbers ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 134, min_bytes_for_wide_part = 624665865, ratio_of_defaults_for_sparse_serialization = 0.37602779269218445, 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 = 516163192, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 12692429, merge_max_block_size = 20046, old_parts_lifetime = 339., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 28875055, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 17768, primary_key_compress_block_size = 15980, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:59.897173 [ 5163 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:46:59.937420 [ 8442 ] {a43b6941-bbec-46cd-9f73-3abd6e5e4154} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack' in scope SELECT * FROM msgpack. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42592) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM msgpack FORMAT MsgPack), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:59.949585 [ 8442 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack' in scope SELECT * FROM msgpack. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:46:59.983111 [ 8432 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:46:59.984092 [ 8432 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:00.299218 [ 3931 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:00.300152 [ 3931 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:00.545996 [ 7755 ] {56e68d0b-7fff-4617-9efa-a56f98dd0085} executeQuery: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42612) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: DROP TABLE msgpack), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:47:00.552175 [ 7755 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:47:00.611835 [ 3931 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:00.613173 [ 3931 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:00.905597 [ 8432 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:00.906924 [ 8432 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:01.267767 [ 8432 ] {26000f18-cf54-4c9d-a0ff-016abb3cb9ec} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42664) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: CREATE TABLE msgpack (array Array(Int64)) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:01.286393 [ 8432 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:01.301914 [ 8442 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:01.305635 [ 8442 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:01.639875 [ 8432 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:01.640782 [ 8432 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:01.924242 [ 8432 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:01.925097 [ 8432 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:01.949511 [ 18380 ] {cd8a7c27-f679-4ddb-8967-2f27b7f35cb9} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addMinutes(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42604) (comment: 01662_date_ubsan.sql) (query 6, line 7) (in query: -- tests with INT64_MIN (via overflow) SELECT addMinutes(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018e2beb6 6. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018e2a836 7. DB::DateTimeAddIntervalImpl::execute(DB::AddMinutesImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018e1d029 8. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018e1ae85 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:47:01.982928 [ 18380 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addMinutes(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018e2beb6 6. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018e2a836 7. DB::DateTimeAddIntervalImpl::execute(DB::AddMinutesImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018e1d029 8. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018e1ae85 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:47:02.088734 [ 3931 ] {be89825d-eabf-4c28-9bc0-68a33c52fcb4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42682) (comment: 01710_projections_partial_optimize_aggregation_in_order.sh) (query 1, line 1) (in query: SELECT DISTINCT name FROM system.processors_profile_log WHERE (query_id = '01710_projections_partial_optimize_aggregation_in_order_test_3-npvlqb') AND (name LIKE 'Aggregating%')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:77: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d7c5 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e828f 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003221c43f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:47:02.136375 [ 3931 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:77: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d7c5 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:279: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e828f 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003221c43f 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:02.162840 [ 8442 ] {5fe6092d-a135-48c4-87a9-9c30d9210bd1} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack' in scope SELECT * FROM msgpack. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42720) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM msgpack), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:02.202508 [ 3931 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:02.203345 [ 3931 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:02.206581 [ 8442 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack' in scope SELECT * FROM msgpack. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:02.370470 [ 18380 ] {51558295-9827-449e-9c82-813a5bd28579} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addHours(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42604) (comment: 01662_date_ubsan.sql) (query 7, line 9) (in query: SELECT addHours(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dc86f8 6. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dc7036 7. DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018db96c9 8. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018db7525 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:47:02.384630 [ 18380 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addHours(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dc86f8 6. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dc7036 7. DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018db96c9 8. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018db7525 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:47:02.523633 [ 8442 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:02.524687 [ 8442 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:02.590946 [ 18380 ] {68ee31b4-a7b2-472d-a8a3-d49947cfdbf8} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addWeeks(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42604) (comment: 01662_date_ubsan.sql) (query 8, line 10) (in query: SELECT addWeeks(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ed38ab 6. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ed21f6 7. DB::DateTimeAddIntervalImpl::execute(DB::AddWeeksImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018ec5489 8. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018ec3285 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:47:02.597952 [ 18380 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addWeeks(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ed38ab 6. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ed21f6 7. DB::DateTimeAddIntervalImpl::execute(DB::AddWeeksImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018ec5489 8. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018ec3285 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:47:02.843887 [ 34297 ] {c0070b70-c63c-4d24-ad86-14ec16954ccc} executeQuery: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42774) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: DROP TABLE msgpack), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:47:02.876174 [ 18380 ] {d4d19015-355f-4e61-b506-91635536800c} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addDays(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42604) (comment: 01662_date_ubsan.sql) (query 9, line 11) (in query: SELECT addDays(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018da48c0 6. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018da30d6 7. DB::DateTimeAddIntervalImpl::execute(DB::AddDaysImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018d94c29 8. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018d92a25 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:47:02.881583 [ 34297 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:47:02.889722 [ 18380 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addDays(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018da48c0 6. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018da30d6 7. DB::DateTimeAddIntervalImpl::execute(DB::AddDaysImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018d94c29 8. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018d92a25 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:47:02.939973 [ 34312 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:02.946699 [ 34312 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:03.102269 [ 18380 ] {89385c4d-8302-424a-89de-c2e00013ca0d} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addYears(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42604) (comment: 01662_date_ubsan.sql) (query 10, line 12) (in query: SELECT addYears(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ef5760 6. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ef3d36 7. DB::DateTimeAddIntervalImpl::execute(DB::AddYearsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018ee6ee9 8. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018ee4ce5 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:47:03.125074 [ 18380 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addYears(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ef5760 6. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ef3d36 7. DB::DateTimeAddIntervalImpl::execute(DB::AddYearsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018ee6ee9 8. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018ee4ce5 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:47:03.252060 [ 34322 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:03.252771 [ 34322 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:03.308712 [ 18380 ] {1b0ec9b1-2620-4a4b-ae3b-caca943c134b} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addMinutes(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42604) (comment: 01662_date_ubsan.sql) (query 11, line 13) (in query: -- tests with inf SELECT addMinutes(toDateTime('2021-01-01 00:00:00', 'GMT'), inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. long DB::Processor::checkOverflow(double) @ 0x0000000018e21cd7 6. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018e2d81d 7. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018e2aa2b 8. DB::DateTimeAddIntervalImpl::execute(DB::AddMinutesImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018e1d029 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018e1ae85 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:47:03.340251 [ 18380 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addMinutes(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. long DB::Processor::checkOverflow(double) @ 0x0000000018e21cd7 6. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018e2d81d 7. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018e2aa2b 8. DB::DateTimeAddIntervalImpl::execute(DB::AddMinutesImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018e1d029 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018e1ae85 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:47:03.521598 [ 18380 ] {307000b8-8b9b-4b1f-9701-f338d1e83a9b} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addHours(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42604) (comment: 01662_date_ubsan.sql) (query 12, line 15) (in query: SELECT addHours(toDateTime('2021-01-01 00:00:00', 'GMT'), inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. long DB::Processor::checkOverflow(double) @ 0x0000000018dbe3d7 6. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dca0bd 7. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dc722b 8. DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018db96c9 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018db7525 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:47:03.536910 [ 34322 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:03.537466 [ 18380 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addHours(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. long DB::Processor::checkOverflow(double) @ 0x0000000018dbe3d7 6. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dca0bd 7. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dc722b 8. DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018db96c9 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018db7525 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:47:03.537908 [ 34322 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:03.553349 [ 34312 ] {5970536b-dcb4-46d3-a719-bfd077b4be43} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32868) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: CREATE TABLE msgpack (date FixedString(10)) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:03.567829 [ 34312 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:03.940946 [ 34312 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:03.942537 [ 34312 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:03.963380 [ 18380 ] {a5ab99b0-2a84-4b84-967a-c0db7f117a62} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addWeeks(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42604) (comment: 01662_date_ubsan.sql) (query 13, line 16) (in query: SELECT addWeeks(toDateTime('2021-01-01 00:00:00', 'GMT'), inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. long DB::Processor::checkOverflow(double) @ 0x0000000018ec9f57 6. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ed523d 7. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ed23eb 8. DB::DateTimeAddIntervalImpl::execute(DB::AddWeeksImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018ec5489 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018ec3285 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:47:03.972863 [ 18380 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addWeeks(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. long DB::Processor::checkOverflow(double) @ 0x0000000018ec9f57 6. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ed523d 7. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ed23eb 8. DB::DateTimeAddIntervalImpl::execute(DB::AddWeeksImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018ec5489 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018ec3285 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:47:04.188899 [ 34322 ] {ad7b9e95-fe06-4f1f-8bdc-3c6515d4d641} executeQuery: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32922) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: INSERT INTO msgpack VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:04.241680 [ 34322 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:04.310298 [ 18380 ] {e657b0e2-64fe-498d-b3cd-bc11d47f2f6d} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addDays(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42604) (comment: 01662_date_ubsan.sql) (query 14, line 17) (in query: SELECT addDays(toDateTime('2021-01-01 00:00:00', 'GMT'), inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. long DB::Processor::checkOverflow(double) @ 0x0000000018d9a2b7 6. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018da621d 7. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018da32cb 8. DB::DateTimeAddIntervalImpl::execute(DB::AddDaysImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018d94c29 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018d92a25 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:47:04.330581 [ 34302 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:04.332345 [ 34302 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:04.337006 [ 18380 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addDays(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. long DB::Processor::checkOverflow(double) @ 0x0000000018d9a2b7 6. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018da621d 7. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018da32cb 8. DB::DateTimeAddIntervalImpl::execute(DB::AddDaysImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018d94c29 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018d92a25 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:47:04.681187 [ 34322 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:04.682085 [ 34322 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:04.733967 [ 18380 ] {2068cf16-5bc1-402d-99ca-9eb0719e2049} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addYears(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42604) (comment: 01662_date_ubsan.sql) (query 15, line 18) (in query: SELECT addYears(toDateTime('2021-01-01 00:00:00', 'GMT'), inf);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. long DB::Processor::checkOverflow(double) @ 0x0000000018eeba57 6. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ef70bd 7. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ef3f2b 8. DB::DateTimeAddIntervalImpl::execute(DB::AddYearsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018ee6ee9 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018ee4ce5 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:47:04.756475 [ 18380 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addYears(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. long DB::Processor::checkOverflow(double) @ 0x0000000018eeba57 6. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ef70bd 7. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018ef3f2b 8. DB::DateTimeAddIntervalImpl::execute(DB::AddYearsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018ee6ee9 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018ee4ce5 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:47:04.831399 [ 34312 ] {6d4f6177-504a-4b4b-8f32-88619a78c273} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack' in scope SELECT * FROM msgpack. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32956) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM msgpack), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:04.848772 [ 34312 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack' in scope SELECT * FROM msgpack. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:05.032512 [ 34302 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:05.036838 [ 34302 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:05.364752 [ 34342 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:05.365849 [ 34342 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:05.372493 [ 34322 ] {ea4d71a5-7640-42e3-a30d-0a2b390bb0f9} executeQuery: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32996) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: DROP TABLE msgpack), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:47:05.393921 [ 34322 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.msgpack does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:47:05.723969 [ 34313 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:05.724927 [ 34313 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:06.003502 [ 34347 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:06.004713 [ 34347 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:06.374763 [ 34322 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:06.380407 [ 34322 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:06.673397 [ 34347 ] {febd80fc-709a-4e06-ad96-e820b91c24bb} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33086) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: CREATE TABLE msgpack_map (m Map(UInt64, UInt64), a Array(Map(UInt64, Array(UInt64)))) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:06.686512 [ 34347 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:06.704182 [ 34370 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:06.705391 [ 34370 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:06.834724 [ 34359 ] {f731aeb4-815a-42ed-8e97-fc4acb77a6a6} executeQuery: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33108) (comment: 02933_replicated_database_forbid_create_as_select.sh) (query 1, line 1) (in query: CREATE TABLE test_ytp1isnr_db.test2 (`id` UInt64) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 42655, min_bytes_for_wide_part = 228068770, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 8, min_bytes_for_full_part_storage = 432774541, compact_parts_max_bytes_to_buffer = 38726650, compact_parts_max_granules_to_buffer = 200, compact_parts_merge_max_bytes_to_prefetch_part = 12150615, merge_max_block_size = 15664, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3410725610, index_granularity_bytes = 13876232, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41516, primary_key_compress_block_size = 40475, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false AS SELECT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:06.893622 [ 34359 ] {} TCPHandler: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:06.968986 [ 34339 ] {1cf1a6e1-ce82-4526-b8e5-8138489b4f04} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33002) (comment: 01624_soft_constraints.sh) (query 10, line 7) (in query: CREATE TABLE hypothesis_test_test (`i` UInt64, `a` UInt64, `b` UInt64, `c` Float64, INDEX t a < b TYPE hypothesis GRANULARITY 1, INDEX t2 b <= c TYPE hypothesis GRANULARITY 1) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 1, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 91, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 487303015, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 19611670, merge_max_block_size = 22288, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 5035149385, index_granularity_bytes = 19107977, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 99281, primary_key_compress_block_size = 64031, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:07.004439 [ 34339 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:07.029111 [ 34359 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:07.030085 [ 34359 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:07.034757 [ 34347 ] {67949c4c-5979-491a-aed4-519d923bd7c6} executeQuery: Code: 57. DB::Exception: Table test_3.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33146) (comment: 03302_analyzer_join_filter_push_down_bug.sql) (query 1, line 1) (in query: CREATE TABLE t1 (key Int32, value DateTime) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:47:07.058473 [ 34347 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:47:07.339985 [ 34347 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:07.341042 [ 34347 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:07.351054 [ 34359 ] {b541111c-5516-43b7-8c7f-d6a90a13f84e} executeQuery: Code: 60. DB::Exception: Table test_11.msgpack_map does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33168) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: INSERT INTO msgpack_map VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:07.399172 [ 34359 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.msgpack_map does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:07.434978 [ 4107 ] {90c43603-6efc-4363-bdc8-064064b321cd} executeQuery: Code: 57. DB::Exception: Table test_9.url_na_log already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42520) (comment: 02461_prewhere_row_level_policy_lightweight_delete.gen.sql) (query 20, line 51) (in query: CREATE TABLE url_na_log (`SiteId` UInt32, `DateVisit` Date) ENGINE = MergeTree PRIMARY KEY SiteId ORDER BY (SiteId, DateVisit) SETTINGS index_granularity = 1000, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 107659964, compact_parts_max_bytes_to_buffer = 170267500, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 4143712, merge_max_block_size = 15640, old_parts_lifetime = 409., prefer_fetch_merged_part_size_threshold = 2669220145, 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 = 20546053, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 36224, primary_key_compress_block_size = 59386, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:47:07.453972 [ 4107 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.url_na_log already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:47:07.642946 [ 34359 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:07.644086 [ 34359 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:07.644747 [ 34322 ] {31b0a65b-27a9-4814-8d88-ad664b777d8c} executeQuery: Code: 344. DB::Exception: CREATE with POPULATE is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. Alternatively, you can enable 'database_replicated_allow_heavy_create' setting to allow this operation, use with caution. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33170) (comment: 02933_replicated_database_forbid_create_as_select.sh) (query 1, line 1) (in query: CREATE MATERIALIZED VIEW test_ytp1isnr_db.test_mv2 (id UInt64) ENGINE = ReplicatedMergeTree ORDER BY id POPULATE AS SELECT 1 AS id), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1696: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc73dcc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:07.693637 [ 34322 ] {} TCPHandler: Code: 344. DB::Exception: CREATE with POPULATE is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. Alternatively, you can enable 'database_replicated_allow_heavy_create' setting to allow this operation, use with caution. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1696: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc73dcc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:07.882531 [ 34322 ] {1205959d-d176-47ab-8aff-a32f779c5150} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack_map' in scope SELECT * FROM msgpack_map. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33208) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM msgpack_map FORMAT MsgPack), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:07.891977 [ 34322 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack_map' in scope SELECT * FROM msgpack_map. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:07.981540 [ 34322 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:07.985491 [ 34322 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:08.271691 [ 34347 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:08.272762 [ 34347 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:08.418012 [ 34322 ] {c3fab082-a2dd-4ca9-842a-e343fbc12a81} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack_map' in scope SELECT * FROM msgpack_map. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33234) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM msgpack_map), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:08.443993 [ 34322 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack_map' in scope SELECT * FROM msgpack_map. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:08.583717 [ 34322 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:08.584587 [ 34322 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:08.880761 [ 34347 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:08.893232 [ 34347 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:08.924263 [ 34322 ] {3f7b85b5-9760-477d-99bf-c7fb1fa2b968} executeQuery: Code: 60. DB::Exception: Table test_11.msgpack_map does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33282) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: DROP TABLE msgpack_map), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:47:08.987957 [ 34322 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.msgpack_map does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:47:09.172802 [ 34347 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:09.173608 [ 34347 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:09.610175 [ 34347 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:09.611273 [ 34347 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:09.930980 [ 3821 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:09.932071 [ 3821 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:10.227154 [ 18510 ] {3f04e50c-e944-4928-a119-188a7712b288} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33354) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: CREATE TABLE msgpack_lc_nullable (a LowCardinality(String), b Nullable(String), c LowCardinality(Nullable(String)), d Array(Nullable(String)), e Array(LowCardinality(Nullable(String)))) engine=Memory()), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:10.239418 [ 18510 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:10.281118 [ 6193 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:10.282931 [ 6193 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:10.593853 [ 5978 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:10.596498 [ 5978 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:10.871455 [ 5978 ] {0715bdfb-4ee7-4a8b-8659-9ae5bc9da224} executeQuery: Code: 60. DB::Exception: Table test_11.msgpack_lc_nullable does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33414) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: INSERT INTO msgpack_lc_nullable VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:10.897827 [ 34347 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:10.898995 [ 34347 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:10.906755 [ 5978 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.msgpack_lc_nullable does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:11.183420 [ 5978 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:11.188602 [ 5978 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:11.348531 [ 18602 ] {6141fc9f-795d-4faa-a1d6-3c980bd970de} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack_lc_nullable' in scope SELECT * FROM msgpack_lc_nullable. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33454) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM msgpack_lc_nullable FORMAT MsgPack), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:11.369187 [ 18602 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack_lc_nullable' in scope SELECT * FROM msgpack_lc_nullable. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:11.462996 [ 5112 ] {0de1125c-fc81-4bf7-896f-f71944cc76c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42260) (comment: 00632_aggregation_window_funnel.sql) (query 46, line 65) (in query: select user, windowFunnel(86400, 'strict_order')(dt, event='a', event='b', event='c') as s from funnel_test_strict_order group by user order by user format JSONCompactEachRow;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc3b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000030e200de 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a5ce1 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:47:11.481374 [ 6193 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:11.487282 [ 6193 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:11.493324 [ 5112 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc3b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000030e200de 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a5ce1 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:47:11.784135 [ 3821 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:11.786357 [ 3821 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:11.907250 [ 34347 ] {b1f37cf0-dea3-4715-8460-54ca9aad9a91} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack_lc_nullable' in scope SELECT * FROM msgpack_lc_nullable. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33480) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM msgpack_lc_nullable), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:11.936961 [ 34347 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'msgpack_lc_nullable' in scope SELECT * FROM msgpack_lc_nullable. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:12.133330 [ 5978 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:12.140382 [ 5978 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:12.484678 [ 8430 ] {48d3aad0-70b0-4423-bfc2-452e80e8aa04} executeQuery: Code: 60. DB::Exception: Table test_11.msgpack_lc_nullable does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33518) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: DROP TABLE msgpack_lc_nullable), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:47:12.592315 [ 8430 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.msgpack_lc_nullable does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:47:12.965686 [ 8430 ] {662ddc21-637f-4734-8fd0-6b07d12787a9} executeQuery: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33560) (comment: 02933_replicated_database_forbid_create_as_select.sh) (query 1, line 1) (in query: CREATE TABLE test_ytp1isnr_db.test2 (`id` UInt64) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 42655, min_bytes_for_wide_part = 228068770, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 8, min_bytes_for_full_part_storage = 432774541, compact_parts_max_bytes_to_buffer = 38726650, compact_parts_max_granules_to_buffer = 200, compact_parts_merge_max_bytes_to_prefetch_part = 12150615, merge_max_block_size = 15664, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3410725610, index_granularity_bytes = 13876232, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41516, primary_key_compress_block_size = 40475, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false AS SELECT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:13.027736 [ 8430 ] {} TCPHandler: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:13.602418 [ 18602 ] {dbb862f6-57da-474a-8075-9899a7cb5f02} executeQuery: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34942) (comment: 02933_replicated_database_forbid_create_as_select.sh) (query 1, line 1) (in query: CREATE TABLE test_ytp1isnr_db.test2 (`id` UInt64) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 42655, min_bytes_for_wide_part = 228068770, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 8, min_bytes_for_full_part_storage = 432774541, compact_parts_max_bytes_to_buffer = 38726650, compact_parts_max_granules_to_buffer = 200, compact_parts_merge_max_bytes_to_prefetch_part = 12150615, merge_max_block_size = 15664, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3410725610, index_granularity_bytes = 13876232, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41516, primary_key_compress_block_size = 40475, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false AS SELECT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:13.622342 [ 18602 ] {} TCPHandler: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:13.784086 [ 8430 ] {ad3250ff-89c0-415e-a815-65f009de8e0b} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type UInt64.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34950) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:265: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x0000000031ab52e7 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9c12 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:47:13.828567 [ 8430 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type UInt64.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:265: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x0000000031ab52e7 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9c12 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:14.568778 [ 7279 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:14.573546 [ 7279 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:14.693778 [ 4171 ] {49d591a9-2328-4628-ad62-90183a5e0992} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type Float32.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35004) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Float32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:265: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x0000000031ab52e7 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9c12 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:47:14.702122 [ 4171 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type Float32.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:265: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x0000000031ab52e7 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9c12 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:14.871610 [ 18602 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:14.872680 [ 18602 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:15.159949 [ 7279 ] {83105a2a-7bd2-4fdd-9366-a6a6aa931908} executeQuery: Code: 306. DB::Exception: JSON is too deep for key 'skipped_field': While executing JSONCompactEachRowRowInputFormat. (TOO_DEEP_RECURSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35042) (comment: 03213_deep_json.sql) (query 1, line 1) (in query: -- The default limit works. SELECT * FROM format("JSONCompactEachRow", 'x UInt32, y UInt32', REPEAT('[1,1,', 100000)) SETTINGS input_format_json_compact_allow_variable_number_of_columns = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/IO/ReadHelpers.cpp:1621: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b5642b 6. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 7. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 8. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 9. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 10. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 11. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 12. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 13. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 14. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 15. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 18. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 19. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 20. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 21. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 22. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 23. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 24. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 25. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 26. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 27. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 28. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 29. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 30. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 31. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 2025.06.13 15:47:15.166430 [ 7279 ] {} TCPHandler: Code: 306. DB::Exception: JSON is too deep for key 'skipped_field': While executing JSONCompactEachRowRowInputFormat. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/IO/ReadHelpers.cpp:1621: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b5642b 6. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 7. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 8. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 9. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 10. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 11. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 12. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 13. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 14. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 15. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 18. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 19. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 20. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 21. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 22. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 23. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 24. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 25. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 26. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 27. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 28. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 29. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 30. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 31. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 2025.06.13 15:47:15.170209 [ 18380 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:15.170874 [ 18380 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:15.194054 [ 18511 ] {66a8ca63-5cfa-41de-8637-b3f9ad14c269} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type Array(UInt32).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35092) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Array(UInt32)')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:265: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x0000000031ab52e7 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9c12 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:47:15.243115 [ 18511 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type Array(UInt32).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:265: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x0000000031ab52e7 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9c12 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:15.467935 [ 4171 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:15.469908 [ 4171 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:15.855998 [ 7279 ] {c575da59-3976-4f76-ab67-313c984274c6} executeQuery: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7f2c83800000, frame address: 0x7f2c83bb8a30, stack size: 4486608, maximum stack size: 8388608: While executing JSONCompactEachRowRowInputFormat. (TOO_DEEP_RECURSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35042) (comment: 03213_deep_json.sql) (query 3, line 5) (in query: SELECT * FROM format("JSONCompactEachRow", 'x UInt32, y UInt32', REPEAT('[1,1,', 100000)) SETTINGS input_format_json_compact_allow_variable_number_of_columns = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x0000000023b1652f 5. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x0000000023b16388 6. ./build_docker/./src/IO/ReadHelpers.cpp:1626: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56446 7. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 8. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 9. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 10. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 11. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 12. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 13. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 14. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 15. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 18. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 19. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 20. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 21. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 22. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 23. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 24. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 25. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 26. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 27. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 28. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 29. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 30. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 31. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 2025.06.13 15:47:15.862436 [ 4171 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Interpreters/Context.cpp:2804: DB::Context::setCurrentDatabaseWithLock(String const&, std::lock_guard const&) @ 0x000000002d47a815 7. ./build_docker/./src/Interpreters/Context.cpp:2812: DB::Context::setCurrentDatabase(String const&) @ 0x000000002d48988e 8. ./build_docker/./src/Server/HTTPHandler.cpp:403: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b53d5 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:15.868643 [ 7279 ] {} TCPHandler: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7f2c83800000, frame address: 0x7f2c83bb8a30, stack size: 4486608, maximum stack size: 8388608: While executing JSONCompactEachRowRowInputFormat. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x0000000023b1652f 5. ./build_docker/./src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x0000000023b16388 6. ./build_docker/./src/IO/ReadHelpers.cpp:1626: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56446 7. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 8. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 9. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 10. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 11. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 12. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 13. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 14. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 15. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 16. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 17. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 18. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 19. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 20. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 21. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 22. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 23. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 24. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 25. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 26. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 27. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 28. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 29. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 30. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 31. ./build_docker/./src/IO/ReadHelpers.cpp:1690: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000023b56856 2025.06.13 15:47:15.949479 [ 9636 ] {1050c7d7-8e55-43a6-b1fd-c31ec0b89971} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type Map(UInt64, UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35120) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Map(UInt64, UInt64)')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:265: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x0000000031ab52e7 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9c12 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:47:16.002176 [ 9636 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack string into column with type Map(UInt64, UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:265: DB::insertString(DB::IColumn&, std::shared_ptr, char const*, unsigned long, bool) @ 0x0000000031ab52e7 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9c12 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:16.219891 [ 18380 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:16.221233 [ 18380 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:16.560134 [ 3931 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:16.564186 [ 3931 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:16.738118 [ 9642 ] {1e5fbec2-e3c5-4a39-b66d-83dcb826bc2d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34976) (comment: 02933_replicated_database_forbid_create_as_select.sh) (query 1, line 1) (in query: DROP DATABASE test_ytp1isnr_db), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:16.773252 [ 9642 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:16.837507 [ 9636 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Interpreters/Context.cpp:2804: DB::Context::setCurrentDatabaseWithLock(String const&, std::lock_guard const&) @ 0x000000002d47a815 7. ./build_docker/./src/Interpreters/Context.cpp:2812: DB::Context::setCurrentDatabase(String const&) @ 0x000000002d48988e 8. ./build_docker/./src/Server/HTTPHandler.cpp:403: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b53d5 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:17.177604 [ 34301 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:17.178556 [ 34301 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:17.358128 [ 18380 ] {d4b395f4-4a26-48a9-9659-fef8de75afd1} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type Float32.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35222) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Float32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:198: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x0000000031ab41bc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac915a 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:47:17.419505 [ 18380 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type Float32.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:198: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x0000000031ab41bc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac915a 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:17.557479 [ 34313 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:17.558686 [ 34313 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:17.703293 [ 34313 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Interpreters/Context.cpp:2804: DB::Context::setCurrentDatabaseWithLock(String const&, std::lock_guard const&) @ 0x000000002d47a815 7. ./build_docker/./src/Interpreters/Context.cpp:2812: DB::Context::setCurrentDatabase(String const&) @ 0x000000002d48988e 8. ./build_docker/./src/Server/HTTPHandler.cpp:403: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b53d5 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:17.982864 [ 34312 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:17.983977 [ 34312 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:17.998160 [ 34313 ] {814ec25d-63a2-4035-8536-19d46a747df9} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type String.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35252) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x String')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:198: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x0000000031ab41bc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac915a 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:47:18.020589 [ 34313 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type String.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:198: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x0000000031ab41bc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac915a 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:18.278954 [ 34312 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:18.279906 [ 34312 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:18.421618 [ 7755 ] {b9037a64-549c-418b-ab14-80703510c6a1} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42644) (comment: 02741_hashed_dictionary_load_factor.gen.sql) (query 22, line 72) (in query: DROP DICTIONARY IF EXISTS test_dictionary_sparse_hashed;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:47:18.440120 [ 7755 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:47:18.451384 [ 34313 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Interpreters/Context.cpp:2804: DB::Context::setCurrentDatabaseWithLock(String const&, std::lock_guard const&) @ 0x000000002d47a815 7. ./build_docker/./src/Interpreters/Context.cpp:2812: DB::Context::setCurrentDatabase(String const&) @ 0x000000002d48988e 8. ./build_docker/./src/Server/HTTPHandler.cpp:403: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b53d5 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:18.652830 [ 34312 ] {d525cdbb-8a7b-4bd7-a429-982c8ce3abfb} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type Array(UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35296) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Array(UInt64)')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:198: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x0000000031ab41bc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac915a 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:47:18.669195 [ 34312 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type Array(UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:198: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x0000000031ab41bc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac915a 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:18.756646 [ 8442 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:18.757470 [ 8442 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:18.776249 [ 4107 ] {04c3a0c6-aaf3-4611-bd74-15126234fb60} executeQuery: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; S. . (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:57858) (comment: 00366_multi_statements.sh) (in query: SELECT 1; S), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:18.791219 [ 4107 ] {04c3a0c6-aaf3-4611-bd74-15126234fb60} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; S. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:18.921098 [ 8442 ] {1df1c1a4-98a7-4e86-9ee5-4e561840cd99} executeQuery: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2. . (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:57884) (comment: 00366_multi_statements.sh) (in query: SELECT 1; SELECT 2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:18.922701 [ 8442 ] {1df1c1a4-98a7-4e86-9ee5-4e561840cd99} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:19.079568 [ 34302 ] {3126cdf3-6660-46b9-a2e5-8198c8ed9439} executeQuery: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2;. . (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:57898) (comment: 00366_multi_statements.sh) (in query: SELECT 1; SELECT 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:19.081185 [ 34302 ] {3126cdf3-6660-46b9-a2e5-8198c8ed9439} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2;. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:19.089072 [ 34339 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:19.095427 [ 34339 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:19.225800 [ 34359 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Interpreters/Context.cpp:2804: DB::Context::setCurrentDatabaseWithLock(String const&, std::lock_guard const&) @ 0x000000002d47a815 7. ./build_docker/./src/Interpreters/Context.cpp:2812: DB::Context::setCurrentDatabase(String const&) @ 0x000000002d48988e 8. ./build_docker/./src/Server/HTTPHandler.cpp:403: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b53d5 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:19.232069 [ 34322 ] {dd9ac345-2d6d-4b78-842f-2704449e0a58} executeQuery: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2; SELECT. . (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:57926) (comment: 00366_multi_statements.sh) (in query: SELECT 1; SELECT 2; SELECT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:19.235193 [ 34301 ] {c99d5a77-bb8d-4d2c-ac54-2e5ac2ebc7bb} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type Map(UInt64, UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35336) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Map(UInt64, UInt64)')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:198: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x0000000031ab41bc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac915a 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:47:19.241652 [ 34322 ] {dd9ac345-2d6d-4b78-842f-2704449e0a58} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2; SELECT. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:19.268789 [ 34301 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack integer into column with type Map(UInt64, UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:198: DB::insertInteger(DB::IColumn&, std::shared_ptr, unsigned long) @ 0x0000000031ab41bc 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac915a 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:19.553591 [ 34370 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:19.564395 [ 34370 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:19.862641 [ 18510 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:19.863580 [ 18510 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:19.886993 [ 34359 ] {} DynamicQueryHandler: Code: 48. DB::Exception: Unsupported compression method. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/IO/CompressionMethod.cpp:197: std::unique_ptr> DB::createWriteCompressedWrapper(DB::WriteBuffer*&, DB::CompressionMethod, int, int, unsigned long, char*, unsigned long, bool) @ 0x0000000023e6604b 6. ./build_docker/./src/IO/CompressionMethod.cpp:231: DB::wrapWriteBufferWithCompressionMethod(DB::WriteBuffer*, DB::CompressionMethod, int, int, unsigned long, char*, unsigned long, bool) @ 0x0000000023e658ed 7. ./build_docker/./src/Server/HTTPHandler.cpp:314: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b3f73 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:20.257257 [ 6193 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:20.258327 [ 6193 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:20.557003 [ 3895 ] {1059014e-89ce-433c-bb2c-74a692f5af54} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type Float32: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35406) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Float32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:415: DB::MsgPackVisitor::start_array(unsigned long) @ 0x0000000031ab7884 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:113: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x0000000031aca2b4 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9ce1 8. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 9. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:47:20.670236 [ 3895 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type Float32: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:415: DB::MsgPackVisitor::start_array(unsigned long) @ 0x0000000031ab7884 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:113: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x0000000031aca2b4 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9ce1 8. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 9. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:20.686651 [ 6193 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:20.694607 [ 6193 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:21.074877 [ 6193 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:21.076812 [ 6193 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:21.210619 [ 34359 ] {19320121-f7fe-4ada-a3f5-bc9fb2e1442d} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type String: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35460) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x String')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:415: DB::MsgPackVisitor::start_array(unsigned long) @ 0x0000000031ab7884 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:113: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x0000000031aca2b4 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9ce1 8. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 9. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:47:21.244326 [ 34359 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type String: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:415: DB::MsgPackVisitor::start_array(unsigned long) @ 0x0000000031ab7884 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:113: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x0000000031aca2b4 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9ce1 8. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 9. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:21.459097 [ 3821 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:21.460984 [ 3821 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:21.700018 [ 5978 ] {7a4929ad-62f5-4e24-8d65-c08d72de8ebd} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type UInt64: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35540) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:415: DB::MsgPackVisitor::start_array(unsigned long) @ 0x0000000031ab7884 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:113: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x0000000031aca2b4 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9ce1 8. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 9. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:47:21.718876 [ 5978 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type UInt64: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:415: DB::MsgPackVisitor::start_array(unsigned long) @ 0x0000000031ab7884 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:113: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x0000000031aca2b4 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9ce1 8. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 9. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:21.772394 [ 34347 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:21.783263 [ 34347 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:47:22.228958 [ 5978 ] {bdcc00c8-d46c-43f6-a247-d2e6e9be84f3} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type Map(UInt64, UInt64): (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35590) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Map(UInt64, UInt64)')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:415: DB::MsgPackVisitor::start_array(unsigned long) @ 0x0000000031ab7884 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:113: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x0000000031aca2b4 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9ce1 8. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 9. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:47:22.255225 [ 5978 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack array into column with type Map(UInt64, UInt64): (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:415: DB::MsgPackVisitor::start_array(unsigned long) @ 0x0000000031ab7884 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:113: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::array_sv, msgpack::v3::detail::context>::array_ev>(msgpack::v3::detail::context>::array_sv const&, msgpack::v3::detail::context>::array_ev const&, char const*, unsigned long&) @ 0x0000000031aca2b4 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:318: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9ce1 8. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 9. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:22.257563 [ 18377 ] {c2114ef3-457e-42e1-874a-c88e3be6c575} executeQuery: Code: 60. DB::Exception: Table test_wh969a56.t_json_11 does not exist. Maybe you meant test_13.t_json_11?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35604) (comment: 01825_type_json_11.sh) (query 1, line 1) (in query: INSERT INTO t_json_11 FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:22.289241 [ 18377 ] {} TCPHandler: Code: 60. DB::Exception: Table test_wh969a56.t_json_11 does not exist. Maybe you meant test_13.t_json_11?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:22.849842 [ 18511 ] {c0f4a3ab-3030-4991-9fbc-82b1d6b25b75} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_11' in scope SELECT DISTINCT toTypeName(obj) FROM t_json_11. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35650) (comment: 01825_type_json_11.sh) (query 1, line 1) (in query: SELECT DISTINCT toTypeName(obj) FROM t_json_11;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:22.876221 [ 18511 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_11' in scope SELECT DISTINCT toTypeName(obj) FROM t_json_11. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:23.264464 [ 34347 ] {745b4516-12c4-46aa-b127-58ca3b7e3da5} executeQuery: Code: 57. DB::Exception: Table test_13.test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43000) (comment: 02868_select_support_from_keywords.sql) (query 1, line 1) (in query: create table test_table ( `date` Date, `__sign` Int8, `from` Float64, `to` Float64 ) ENGINE = CollapsingMergeTree(__sign) PARTITION BY toYYYYMM(date) ORDER BY (date) SETTINGS index_granularity = 8192;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:47:23.281387 [ 34347 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:47:23.411398 [ 3821 ] {8dc3a164-ed2b-4e41-8463-4dfc952d4e8d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_11' in scope SELECT obj FROM t_json_11 ORDER BY obj.id ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43014) (comment: 01825_type_json_11.sh) (query 1, line 1) (in query: SELECT obj FROM t_json_11 ORDER BY obj.id FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:23.428205 [ 3821 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_11' in scope SELECT obj FROM t_json_11 ORDER BY obj.id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:23.520301 [ 18377 ] {816db66f-dc90-484e-8278-7706a960663f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43022) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Float32')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:23.614344 [ 18377 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:23.880421 [ 18377 ] {6455be97-9efc-478a-869d-253867c23193} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_11' in scope SELECT obj.key_1.key_3 FROM t_json_11 ORDER BY obj.id ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43064) (comment: 01825_type_json_11.sh) (query 1, line 1) (in query: SELECT obj.key_1.key_3 FROM t_json_11 ORDER BY obj.id FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:23.924494 [ 18377 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_11' in scope SELECT obj.key_1.key_3 FROM t_json_11 ORDER BY obj.id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:24.180382 [ 18377 ] {5101cd71-9edc-44f4-8c4f-c1b322db5ce3} executeQuery: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43094) (comment: 02933_replicated_database_forbid_create_as_select.sh) (query 1, line 1) (in query: CREATE TABLE test_dykw4rlt_db.test2 (`id` UInt64) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 42655, min_bytes_for_wide_part = 228068770, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 8, min_bytes_for_full_part_storage = 432774541, compact_parts_max_bytes_to_buffer = 38726650, compact_parts_max_granules_to_buffer = 200, compact_parts_merge_max_bytes_to_prefetch_part = 12150615, merge_max_block_size = 15664, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3410725610, index_granularity_bytes = 13876232, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41516, primary_key_compress_block_size = 40475, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false AS SELECT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:24.192304 [ 18377 ] {} TCPHandler: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:24.356767 [ 8430 ] {844bcb02-59cf-473e-ab08-8e6e7017e3e0} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack map into column with type String.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43078) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x String')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:440: DB::MsgPackVisitor::start_map(unsigned int) @ 0x0000000031ab7fbd 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:130: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::map_sv, msgpack::v3::detail::context>::map_ev>(msgpack::v3::detail::context>::map_sv const&, msgpack::v3::detail::context>::map_ev const&, char const*, unsigned long&) @ 0x0000000031aca494 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:321: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9d2c 8. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 9. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:47:24.377402 [ 5110 ] {bf8e64ff-8ab5-40b8-a7e4-b56b5ff2cb6b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_11' in scope SELECT obj.key_1.key_3.key_4.key_5, obj.key_1.key_3.key_7 FROM t_json_11 ORDER BY obj.id ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43100) (comment: 01825_type_json_11.sh) (query 1, line 1) (in query: SELECT obj.key_1.key_3.key_4.key_5, obj.key_1.key_3.key_7 FROM t_json_11 ORDER BY obj.id), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:24.395148 [ 8430 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack map into column with type String.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:440: DB::MsgPackVisitor::start_map(unsigned int) @ 0x0000000031ab7fbd 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:130: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::map_sv, msgpack::v3::detail::context>::map_ev>(msgpack::v3::detail::context>::map_sv const&, msgpack::v3::detail::context>::map_ev const&, char const*, unsigned long&) @ 0x0000000031aca494 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:321: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9d2c 8. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 9. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:24.418282 [ 5110 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_11' in scope SELECT obj.key_1.key_3.key_4.key_5, obj.key_1.key_3.key_7 FROM t_json_11 ORDER BY obj.id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:24.818107 [ 8430 ] {87ace4eb-e3ce-409d-b25d-27e93fca34d5} executeQuery: Code: 344. DB::Exception: CREATE with POPULATE is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. Alternatively, you can enable 'database_replicated_allow_heavy_create' setting to allow this operation, use with caution. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43106) (comment: 02933_replicated_database_forbid_create_as_select.sh) (query 1, line 1) (in query: CREATE MATERIALIZED VIEW test_dykw4rlt_db.test_mv2 (id UInt64) ENGINE = ReplicatedMergeTree ORDER BY id POPULATE AS SELECT 1 AS id), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1696: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc73dcc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:24.855504 [ 8430 ] {} TCPHandler: Code: 344. DB::Exception: CREATE with POPULATE is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. Alternatively, you can enable 'database_replicated_allow_heavy_create' setting to allow this operation, use with caution. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1696: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc73dcc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:24.979717 [ 5110 ] {89c27959-130f-4274-a630-cb7678428e3c} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack map into column with type UInt64.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43112) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:440: DB::MsgPackVisitor::start_map(unsigned int) @ 0x0000000031ab7fbd 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:130: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::map_sv, msgpack::v3::detail::context>::map_ev>(msgpack::v3::detail::context>::map_sv const&, msgpack::v3::detail::context>::map_ev const&, char const*, unsigned long&) @ 0x0000000031aca494 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:321: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9d2c 8. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 9. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:47:25.155225 [ 5110 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack map into column with type UInt64.: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:440: DB::MsgPackVisitor::start_map(unsigned int) @ 0x0000000031ab7fbd 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:130: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::map_sv, msgpack::v3::detail::context>::map_ev>(msgpack::v3::detail::context>::map_sv const&, msgpack::v3::detail::context>::map_ev const&, char const*, unsigned long&) @ 0x0000000031aca494 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:321: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9d2c 8. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 9. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:25.174883 [ 3821 ] {b566d5a8-3c0d-4149-873a-4f00a6f7db53} executeQuery: Code: 60. DB::Exception: Table test_wh969a56.t_json_11 does not exist. Maybe you meant test_13.t_json_11?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43114) (comment: 01825_type_json_11.sh) (query 1, line 1) (in query: DROP TABLE t_json_11;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:47:25.197886 [ 3821 ] {} TCPHandler: Code: 60. DB::Exception: Table test_wh969a56.t_json_11 does not exist. Maybe you meant test_13.t_json_11?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:47:25.656119 [ 18511 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:25.666035 [ 18511 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:25.831374 [ 7279 ] {fca592ae-0593-49e1-aca7-8e2b05d14784} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack map into column with type Array(UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43132) (comment: 01098_msgpack_format.sh) (query 1, line 1) (in query: SELECT * FROM file('data.msgpack', 'MsgPack', 'x Array(UInt64)')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:440: DB::MsgPackVisitor::start_map(unsigned int) @ 0x0000000031ab7fbd 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:130: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::map_sv, msgpack::v3::detail::context>::map_ev>(msgpack::v3::detail::context>::map_sv const&, msgpack::v3::detail::context>::map_ev const&, char const*, unsigned long&) @ 0x0000000031aca494 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:321: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9d2c 8. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 9. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:47:25.869261 [ 7279 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack map into column with type Array(UInt64).: (in file/uri /var/lib/clickhouse/user_files/data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:440: DB::MsgPackVisitor::start_map(unsigned int) @ 0x0000000031ab7fbd 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:130: msgpack::v2::parse_return msgpack::v3::detail::context>::start_aggregate>::map_sv, msgpack::v3::detail::context>::map_ev>(msgpack::v3::detail::context>::map_sv const&, msgpack::v3::detail::context>::map_ev const&, char const*, unsigned long&) @ 0x0000000031aca494 7. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:321: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000031ac9d2c 8. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:633: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000031abf3f6 9. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000031ababb1 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x00000000303dece0 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:26.270775 [ 18511 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:26.271932 [ 18511 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:26.649720 [ 7279 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:26.659116 [ 7279 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:27.016425 [ 3821 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:27.017596 [ 3821 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:27.592098 [ 18511 ] {87aad0fa-4ec7-4553-97d2-3fe74d33e650} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43238) (comment: 02961_analyzer_low_cardinality_fuzzer.sql) (query 2, line 3) (in query: CREATE TABLE test_tuple_filter__fuzz_2 (`id` Nullable(UInt32), `value` LowCardinality(String), `log_date` LowCardinality(Date)) ENGINE = MergeTree PARTITION BY log_date ORDER BY id SETTINGS allow_nullable_key = 1, index_granularity = 16828, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.5189524292945862, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 69959209, compact_parts_max_bytes_to_buffer = 98155019, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 2652312, merge_max_block_size = 16379, old_parts_lifetime = 56., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 413133, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10107254641, index_granularity_bytes = 26013547, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 4, 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 = 72963, primary_key_compress_block_size = 97199, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:27.604118 [ 18511 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:28.545611 [ 9636 ] {9edfedca-d083-4e78-8d03-a92fb81107e4} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43274) (comment: 03156_dynamic_type_concurrent_inserts.sh) (query 1, line 1) (in query: CREATE TABLE test_cc (d Dynamic) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:28.556616 [ 9636 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:28.634132 [ 4171 ] {f2a98ba4-0bcd-4350-bfc0-cd5be63a9627} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43266) (comment: 01253_subquery_in_aggregate_function_JustStranger.sql) (query 1, line 1) (in query: DROP TABLE IF EXISTS test_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:47:28.674319 [ 4171 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.135493 [ 7279 ] {29a9d4fd-0155-40c1-9ba6-8d16fe14426f} executeQuery: Code: 60. DB::Exception: Table test_11.test_cc does not exist. Maybe you meant test_13.test_dict?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43298) (comment: 03156_dynamic_type_concurrent_inserts.sh) (query 1, line 1) (in query: INSERT INTO test_cc SELECT map(number, toString(number)) AS d FROM numbers(10000) SETTINGS max_threads=6,max_insert_threads=6), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.136674 [ 4171 ] {c9420ba8-c27a-40b5-a782-0f5c4cd1fd70} executeQuery: Code: 60. DB::Exception: Table test_11.test_cc does not exist. Maybe you meant test_13.test_dict?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43302) (comment: 03156_dynamic_type_concurrent_inserts.sh) (query 1, line 1) (in query: INSERT INTO test_cc SELECT toFloat64(number) AS d FROM numbers(10000) SETTINGS max_threads=5,max_insert_threads=5), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.151586 [ 9636 ] {26c5da82-937c-40d4-9576-af988734ba03} executeQuery: Code: 60. DB::Exception: Table test_11.test_cc does not exist. Maybe you meant test_13.test_dict?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43318) (comment: 03156_dynamic_type_concurrent_inserts.sh) (query 1, line 1) (in query: INSERT INTO test_cc SELECT CAST(multiIf(number % 5 = 0, toString(number), number % 5 = 1, number, number % 5 = 2, toFloat64(number), number % 5 = 3, toDate('2020-01-01'), [number, number + 1]), 'Dynamic') FROM numbers(10000) SETTINGS max_threads=6,max_insert_threads=6), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.156062 [ 9636 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.test_cc does not exist. Maybe you meant test_13.test_dict?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.166929 [ 4171 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.test_cc does not exist. Maybe you meant test_13.test_dict?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.167183 [ 7279 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.test_cc does not exist. Maybe you meant test_13.test_dict?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.201825 [ 18380 ] {9cd74c3a-cda2-4ef6-8a43-6f68b4893972} executeQuery: Code: 60. DB::Exception: Table test_11.test_cc does not exist. Maybe you meant test_13.test_dict?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43356) (comment: 03156_dynamic_type_concurrent_inserts.sh) (query 1, line 1) (in query: INSERT INTO test_cc SELECT [number, number + 1] AS d FROM numbers(10000) SETTINGS max_threads=4,max_insert_threads=4), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.202660 [ 2860 ] {3a9da317-bed5-4598-84c8-c324713e506f} executeQuery: Code: 60. DB::Exception: Table test_11.test_cc does not exist. Maybe you meant test_13.test_dict?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43332) (comment: 03156_dynamic_type_concurrent_inserts.sh) (query 1, line 1) (in query: INSERT INTO test_cc SELECT number::Int64 AS d FROM numbers(10000) SETTINGS max_threads=1,max_insert_threads=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.206853 [ 5163 ] {43db20f4-9833-4829-b3fb-e0d404db8628} executeQuery: Code: 60. DB::Exception: Table test_11.test_cc does not exist. Maybe you meant test_13.test_dict?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43342) (comment: 03156_dynamic_type_concurrent_inserts.sh) (query 1, line 1) (in query: INSERT INTO test_cc SELECT toDate(number % 10000) AS d FROM numbers(10000) SETTINGS max_threads=3,max_insert_threads=3), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.221910 [ 18380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.test_cc does not exist. Maybe you meant test_13.test_dict?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.224010 [ 2860 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.test_cc does not exist. Maybe you meant test_13.test_dict?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.253021 [ 5163 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.test_cc does not exist. Maybe you meant test_13.test_dict?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.254963 [ 6234 ] {4b4154a9-62a1-451e-a491-c002a7fd1911} executeQuery: Code: 60. DB::Exception: Table test_11.test_cc does not exist. Maybe you meant test_13.test_dict?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43362) (comment: 03156_dynamic_type_concurrent_inserts.sh) (query 1, line 1) (in query: INSERT INTO test_cc SELECT toString(number) AS d FROM numbers(10000) SETTINGS max_threads=2,max_insert_threads=2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.262022 [ 6234 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.test_cc does not exist. Maybe you meant test_13.test_dict?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.417581 [ 4171 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:29.418441 [ 4171 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:29.751180 [ 7279 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:29.760213 [ 7279 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:29.924235 [ 5005 ] {5f165587-06e2-4014-8efc-4b730183d884} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_cc' in scope SELECT dynamicType(d) AS t, count(), uniqExact(d) FROM test_cc GROUP BY t ORDER BY t ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43418) (comment: 03156_dynamic_type_concurrent_inserts.sh) (query 1, line 1) (in query: SELECT dynamicType(d) t, count(), uniqExact(d) FROM test_cc GROUP BY t ORDER BY t), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:29.940939 [ 5005 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_cc' in scope SELECT dynamicType(d) AS t, count(), uniqExact(d) FROM test_cc GROUP BY t ORDER BY t ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:30.064235 [ 8432 ] {96295afe-a126-4e42-8e72-bd0b869e0437} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43364) (comment: 03040_dynamic_type_alters_1_compact_merge_tree.sql) (query 5, line 6) (in query: CREATE TABLE test (`x` UInt64, `y` UInt64) ENGINE = MergeTree ORDER BY x SETTINGS min_rows_for_wide_part = 100000000, min_bytes_for_wide_part = 1000000000, index_granularity = 44686, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 41, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 172600526, compact_parts_max_granules_to_buffer = 242, compact_parts_merge_max_bytes_to_prefetch_part = 28952992, merge_max_block_size = 1216, old_parts_lifetime = 218., prefer_fetch_merged_part_size_threshold = 9271493967, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 6493020690, index_granularity_bytes = 18809440, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 53, 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 = 27226, primary_key_compress_block_size = 17607, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:30.065227 [ 7279 ] {2b3433f1-3f74-4db0-a0a6-c5f1ce31ce01} executeQuery: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43454) (comment: 02933_replicated_database_forbid_create_as_select.sh) (query 1, line 1) (in query: CREATE TABLE test_dykw4rlt_db.test2 (`id` UInt64) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 42655, min_bytes_for_wide_part = 228068770, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 8, min_bytes_for_full_part_storage = 432774541, compact_parts_max_bytes_to_buffer = 38726650, compact_parts_max_granules_to_buffer = 200, compact_parts_merge_max_bytes_to_prefetch_part = 12150615, merge_max_block_size = 15664, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3410725610, index_granularity_bytes = 13876232, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41516, primary_key_compress_block_size = 40475, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false AS SELECT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:30.082920 [ 5005 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:30.084015 [ 5005 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:30.090609 [ 8432 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:30.090807 [ 7279 ] {} TCPHandler: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:30.377067 [ 7279 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:30.378153 [ 7279 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:30.692609 [ 18511 ] {41768884-583d-44d5-b9a9-9c2f3b13cf70} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43260) (query 9, line 12) (in query: select hostname from system.query_log where query like 'select \'02095_system_logs_hostname%' and current_database = currentDatabase() and event_date >= yesterday() LIMIT 1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:77: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d7c5 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:47:30.779731 [ 18511 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:77: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d7c5 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:30.788068 [ 9636 ] {ab6c56a9-f756-4f04-9162-b06ac6071d82} executeQuery: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43496) (comment: 02933_replicated_database_forbid_create_as_select.sh) (query 1, line 1) (in query: CREATE TABLE test_dykw4rlt_db.test2 (`id` UInt64) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 42655, min_bytes_for_wide_part = 228068770, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 8, min_bytes_for_full_part_storage = 432774541, compact_parts_max_bytes_to_buffer = 38726650, compact_parts_max_granules_to_buffer = 200, compact_parts_merge_max_bytes_to_prefetch_part = 12150615, merge_max_block_size = 15664, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3410725610, index_granularity_bytes = 13876232, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41516, primary_key_compress_block_size = 40475, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false AS SELECT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:30.793818 [ 18380 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:30.802118 [ 18380 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:30.815560 [ 9636 ] {} TCPHandler: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:30.973831 [ 5005 ] {c90965a6-7c5d-4f55-bf48-ae138e400c40} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43482) (comment: 00623_in_partition_key.sql) (query 3, line 3) (in query: create table test54378 (part_date Date, pk_date Date, date Date) Engine=MergeTree(part_date, pk_date, 8192);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:30.991998 [ 5005 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:31.161247 [ 6234 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:31.162418 [ 6234 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:31.488791 [ 7755 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:31.490947 [ 7755 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:31.685013 [ 18380 ] {0d7c4da1-e817-46a8-8577-efef3b919a9d} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 76.38 MiB (attempt to allocate chunk of 76.38 MiB bytes), maximum: 15.26 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43550) (comment: 01109_inflating_cross_join.sql) (query 3, line 4) (in query: SELECT count(*) FROM numbers(10000) n1 CROSS JOIN numbers(1000) n2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239910e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc3c26 10. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:880: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const @ 0x000000002e456626 11. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1050: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e45a64d 12. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dc59be 13. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003212c47c 14. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x0000000032128e8a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002ddd0d6b 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddaf66d 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1628: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd972f8 18. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 19. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:47:31.727426 [ 18380 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 76.38 MiB (attempt to allocate chunk of 76.38 MiB bytes), maximum: 15.26 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239910e3 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017cc3c26 10. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:880: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const @ 0x000000002e456626 11. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1050: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x000000002e45a64d 12. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x0000000031dc59be 13. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003212c47c 14. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x0000000032128e8a 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x000000002ddd0d6b 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1531: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000002ddaf66d 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1628: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd972f8 18. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 19. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:47:31.779047 [ 34301 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:31.779873 [ 34301 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:32.070516 [ 34297 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:32.075963 [ 34297 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:32.463161 [ 8432 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:32.472248 [ 8432 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:32.550747 [ 34301 ] {000e72b4-8281-4983-9dc2-ba67a3367403} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43674) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:47:32.561477 [ 34301 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:47:32.770661 [ 34301 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:32.771830 [ 34301 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:33.134349 [ 34301 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:33.135408 [ 34301 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:33.561234 [ 34312 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:33.584315 [ 34312 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:33.860070 [ 6234 ] {095eeff5-b019-4759-af66-3096bca68fa0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43562) (comment: 02933_replicated_database_forbid_create_as_select.sh) (query 1, line 1) (in query: DROP DATABASE test_dykw4rlt_db), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:33.876269 [ 6234 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:33.876519 [ 34301 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:33.889423 [ 34301 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:34.202364 [ 34312 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:34.203531 [ 34312 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:34.511372 [ 34302 ] {3f853a9c-376a-4df8-9051-c4b8e36bd2b6} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44010) (comment: 01197_summing_enum.sql) (query 2, line 3) (in query: CREATE TABLE summing (`k` String, `x` UInt64, `e` Enum('hello' = 1, 'world' = 2)) ENGINE = SummingMergeTree ORDER BY k SETTINGS index_granularity = 36529, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.2931526005268097, replace_long_file_name_to_hash = false, max_file_name_length = 106, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 434572749, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 15939431, merge_max_block_size = 2541, old_parts_lifetime = 52., prefer_fetch_merged_part_size_threshold = 3736402577, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9006047027, index_granularity_bytes = 15913432, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 31913, primary_key_compress_block_size = 94373, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:34.512826 [ 4107 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:34.513604 [ 4107 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:34.520725 [ 34302 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:34.904263 [ 8432 ] {f043e58c-2a73-42a4-a705-7b8a90593c3a} executeQuery: Code: 344. DB::Exception: FINAL modifier is not supported with parallel replicas. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43704) (comment: 02765_parallel_replicas_final_modifier.sql) (query 8, line 13) (in query: SELECT * FROM parallel_replicas_final FINAL FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Planner/Planner.cpp:1532: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6e7c7 6. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:47:34.924096 [ 34313 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:34.925359 [ 34313 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:34.928070 [ 8432 ] {} TCPHandler: Code: 344. DB::Exception: FINAL modifier is not supported with parallel replicas. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Planner/Planner.cpp:1532: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6e7c7 6. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:47:35.608656 [ 34302 ] {478aeb49-8420-4549-99e9-1afec6b7d685::all_3_4_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:35.631731 [ 34302 ] {5db4fbf6-30ac-4d6e-bd12-be00f6b50878} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44094) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:47:35.651587 [ 34302 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:47:36.285705 [ 5163 ] {d4f6f0e0-a872-45fa-8570-064e430bdd3f} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e') AS v, toTypeName(v). (UNKNOWN_SETTING) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43604) (comment: 01418_custom_settings.sql) (query 23, line 26) (in query: SELECT getSetting('custom_e') as v, toTypeName(v);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c07d5e0 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c27a727 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c27a528 7. ./build_docker/./src/Core/Settings.cpp:6484: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c17e718 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc2078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc1eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:47:36.291736 [ 5163 ] {} TCPHandler: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e') AS v, toTypeName(v). (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c07d5e0 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c27a727 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c27a528 7. ./build_docker/./src/Core/Settings.cpp:6484: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c17e718 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc2078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc1eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:47:37.055682 [ 5163 ] {b2a76782-cba2-46a1-a486-1564f1ac7a04} executeQuery: Code: 115. DB::Exception: Setting invalid_custom is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43604) (comment: 01418_custom_settings.sql) (query 27, line 31) (in query: SET invalid_custom = 8;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Access/AccessControl.cpp:134: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002bcc4a7c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:279: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9238 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:37.062938 [ 5163 ] {} TCPHandler: Code: 115. DB::Exception: Setting invalid_custom is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Access/AccessControl.cpp:134: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002bcc4a7c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:279: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9238 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:37.443229 [ 34312 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:37.456188 [ 34312 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:37.751683 [ 34313 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:37.752692 [ 34313 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:38.034518 [ 34339 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:38.035752 [ 34339 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:38.544056 [ 34370 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:38.548187 [ 34370 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:38.757438 [ 3895 ] {09a6ee6a-4a75-4216-bdd1-beffa4cb0c37} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44272) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:47:38.784327 [ 3895 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:47:38.833465 [ 3895 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:38.834273 [ 3895 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:38.961793 [ 34313 ] {dd4a4709-7166-4261-9662-2251ce8b7797} 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.20286.altinityantalya (altinity build)) (from [::1]:44234) (comment: 00732_quorum_insert_lost_part_and_alive_part_zookeeper_long.sql) (query 4, line 10) (in query: CREATE TABLE quorum1 (`x` UInt32, `y` Date) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_00732/quorum_lost_alive', '1') PARTITION BY y ORDER BY x SETTINGS index_granularity = 34733, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 8, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 422063681, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 14037735, merge_max_block_size = 1418, old_parts_lifetime = 410., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 14781517, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 58650, primary_key_compress_block_size = 42031, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:38.989467 [ 5163 ] {5466eee9-11bc-4f65-9099-2df66ed2e336} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_f': In scope SELECT getSetting('custom_f') AS v, toTypeName(v). (UNKNOWN_SETTING) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43604) (comment: 01418_custom_settings.sql) (query 35, line 41) (in query: SELECT getSetting('custom_f') as v, toTypeName(v);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c07d5e0 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c27a727 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c27a528 7. ./build_docker/./src/Core/Settings.cpp:6484: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c17e718 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc2078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc1eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:47:38.990617 [ 34313 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:39.011202 [ 5163 ] {} TCPHandler: Code: 115. DB::Exception: Unknown setting 'custom_f': In scope SELECT getSetting('custom_f') AS v, toTypeName(v). (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c07d5e0 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c27a727 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c27a528 7. ./build_docker/./src/Core/Settings.cpp:6484: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c17e718 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc2078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc1eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:47:39.041425 [ 3821 ] {98594576-b923-41a2-86a9-48542bda6c71} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 5.10 MiB (attempt to allocate chunk of 1.07 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43228) (comment: 00927_asof_join_long.sql) (query 6, line 21) (in query: SELECT SUM(trades.price - tvs.tv) FROM (SELECT k, t, t as price FROM (SELECT toUInt32(number) AS k FROM numbers(1000)) keys CROSS JOIN (SELECT toUInt32(number * 10) AS t FROM numbers(3000)) trade_times SETTINGS join_algorithm = 'hash') trades ASOF LEFT JOIN tvs USING(k,t) SETTINGS join_algorithm = 'full_sorting_merge';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc3b14 10. ./src/Common/PODArray.h:112: auto DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto)::operator()::less>(auto, auto, auto) const @ 0x00000000300c0e8d 11. ./src/Columns/IColumnImpl.h:154: void DB::IColumn::updatePermutationImpl::less, DB::ColumnVector::equals, DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto), DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto, auto)>(unsigned long, DB::PODArray, 63ul, 64ul>&, std::vector>&, auto, auto, auto, auto) const @ 0x000000002ff99cfe 12. ./build_docker/./src/Columns/ColumnVector.cpp:386: DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const @ 0x000000002ff998b9 13. ./build_docker/./src/Interpreters/sortBlock.cpp:195: DB::(anonymous namespace)::getBlockSortPermutationImpl(DB::Block const&, DB::SortDescription const&, DB::IColumn::PermutationSortStability, unsigned long, DB::PODArray, 63ul, 64ul>&) @ 0x000000002e37ebb5 14. ./build_docker/./src/Interpreters/sortBlock.cpp:339: DB::sortBlock(DB::Block&, DB::SortDescription const&, unsigned long) @ 0x000000002e37e14a 15. ./build_docker/./src/Processors/Transforms/PartialSortingTransform.cpp:137: DB::PartialSortingTransform::transform(DB::Chunk&) @ 0x0000000031e0ff35 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:47:39.062508 [ 8101 ] {12c974bf-c9a0-4ac2-9ce0-503bc5aab4a9} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 697, line 697) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) - N as r FORMAT CSV;) 2025.06.13 15:47:39.079543 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:39.087033 [ 3821 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 5.10 MiB (attempt to allocate chunk of 1.07 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc3b14 10. ./src/Common/PODArray.h:112: auto DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto)::operator()::less>(auto, auto, auto) const @ 0x00000000300c0e8d 11. ./src/Columns/IColumnImpl.h:154: void DB::IColumn::updatePermutationImpl::less, DB::ColumnVector::equals, DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto), DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const::'lambda'(auto, auto, auto, auto)>(unsigned long, DB::PODArray, 63ul, 64ul>&, std::vector>&, auto, auto, auto, auto) const @ 0x000000002ff99cfe 12. ./build_docker/./src/Columns/ColumnVector.cpp:386: DB::ColumnVector::updatePermutation(DB::IColumn::PermutationSortDirection, DB::IColumn::PermutationSortStability, unsigned long, int, DB::PODArray, 63ul, 64ul>&, std::vector>&) const @ 0x000000002ff998b9 13. ./build_docker/./src/Interpreters/sortBlock.cpp:195: DB::(anonymous namespace)::getBlockSortPermutationImpl(DB::Block const&, DB::SortDescription const&, DB::IColumn::PermutationSortStability, unsigned long, DB::PODArray, 63ul, 64ul>&) @ 0x000000002e37ebb5 14. ./build_docker/./src/Interpreters/sortBlock.cpp:339: DB::sortBlock(DB::Block&, DB::SortDescription const&, unsigned long) @ 0x000000002e37e14a 15. ./build_docker/./src/Processors/Transforms/PartialSortingTransform.cpp:137: DB::PartialSortingTransform::transform(DB::Chunk&) @ 0x0000000031e0ff35 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:47:39.142126 [ 5112 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:39.144323 [ 5112 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:39.225053 [ 8101 ] {f96dbdf7-ad10-4a9d-a2f5-3dbd82058561} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 698, line 698) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt8(1) - N as r FORMAT CSV;) 2025.06.13 15:47:39.240735 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:39.354008 [ 8101 ] {992704be-388d-4aa5-b819-ca0d9eb6d6c4} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 699, line 699) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt8(1) - N as r FORMAT CSV;) 2025.06.13 15:47:39.373697 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:39.514559 [ 5112 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:39.525323 [ 5112 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:39.596111 [ 3931 ] {2bf773f9-13b9-47be-b5c9-c19612d8c6f5} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44120) (comment: 02185_range_hashed_dictionary_open_ranges.sql) (query 16, line 39) (in query: DROP DICTIONARY 02185_range_dictionary;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:47:39.712807 [ 3931 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:47:39.816041 [ 6193 ] {0d6042c6-59b0-40ce-b8b7-c8c4ab852671} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44360) (comment: 00543_access_to_temporary_table_in_readonly_mode.sh) (query 2, line 3) (in query: CREATE TABLE test_readonly ( ID Int ) Engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:39.835440 [ 34370 ] {45cf748c-5241-4497-b995-a7192051f10a} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44334) (comment: 02481_low_cardinality_with_short_circuit_functins_mutations.sql) (query 2, line 3) (in query: CREATE TABLE issue_46128 (`id` Int64, `a` LowCardinality(Nullable(String)), `b` LowCardinality(Nullable(String))) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 65114, min_bytes_for_wide_part = 0, 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 = 475343420, compact_parts_max_granules_to_buffer = 177, compact_parts_merge_max_bytes_to_prefetch_part = 7219400, merge_max_block_size = 2596, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1178353548, index_granularity_bytes = 24477266, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 54289, primary_key_compress_block_size = 85508, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false AS SELECT number % 100, 'xxxx', 'yyyy' FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:39.852357 [ 6193 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:39.852980 [ 34370 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:39.880347 [ 3895 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:39.888769 [ 3895 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:40.245850 [ 4172 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:40.247365 [ 4172 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_7 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000002d5ec639 6. ./build_docker/./src/Server/TCPHandler.cpp:341: DB::TCPHandler::runImpl() @ 0x00000000316a18f5 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:40.485346 [ 6193 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'min_compress_block_size' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000028493136 4. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9e8f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 7. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 8. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 9. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 10. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 11. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:47:40.514722 [ 6193 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:47:41.179885 [ 18510 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'min_compress_block_size' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000028493136 4. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9e8f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 7. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 8. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 9. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 10. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 11. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:47:41.190082 [ 18510 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:47:41.382415 [ 8101 ] {3cd4358c-f95c-445e-82f5-c6d844ce6637} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 707, line 707) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) - N as r FORMAT CSV;) 2025.06.13 15:47:41.427774 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:41.688782 [ 8101 ] {0c4c54a3-06dd-427c-80e2-2ecb2cf24c50} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 708, line 708) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt8(-1) - N as r FORMAT CSV;) 2025.06.13 15:47:41.694172 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:41.777780 [ 3895 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'min_compress_block_size' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000028493136 4. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9e8f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 7. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 8. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 9. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 10. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 11. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:47:41.795919 [ 3895 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:47:41.832852 [ 8101 ] {739ec1e1-6eef-46b0-84c9-1fa77f88f9d7} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 709, line 709) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt8(-1) - N as r FORMAT CSV;) 2025.06.13 15:47:41.852220 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:41.900961 [ 18510 ] {46a90d64-5d19-4eb8-80ea-d69d35074ea9} executeQuery: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44468) (comment: 02933_replicated_database_forbid_create_as_select.sh) (query 1, line 1) (in query: CREATE TABLE test_ni7k46pi_db.test2 (`id` UInt64) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 42655, min_bytes_for_wide_part = 228068770, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 8, min_bytes_for_full_part_storage = 432774541, compact_parts_max_bytes_to_buffer = 38726650, compact_parts_max_granules_to_buffer = 200, compact_parts_merge_max_bytes_to_prefetch_part = 12150615, merge_max_block_size = 15664, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3410725610, index_granularity_bytes = 13876232, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41516, primary_key_compress_block_size = 40475, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false AS SELECT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:41.928699 [ 18510 ] {} TCPHandler: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:42.090199 [ 6193 ] {478aeb49-8420-4549-99e9-1afec6b7d685::all_7_8_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:42.096787 [ 6193 ] {75049166-23a9-4ede-b6b5-7f3b8f26df40} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44480) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:47:42.122200 [ 6193 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:47:42.629365 [ 5978 ] {3080816d-d003-4c0a-a012-561a930e93cc} executeQuery: Code: 344. DB::Exception: CREATE with POPULATE is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. Alternatively, you can enable 'database_replicated_allow_heavy_create' setting to allow this operation, use with caution. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44554) (comment: 02933_replicated_database_forbid_create_as_select.sh) (query 1, line 1) (in query: CREATE MATERIALIZED VIEW test_ni7k46pi_db.test_mv2 (id UInt64) ENGINE = ReplicatedMergeTree ORDER BY id POPULATE AS SELECT 1 AS id), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1696: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc73dcc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:42.667157 [ 5978 ] {} TCPHandler: Code: 344. DB::Exception: CREATE with POPULATE is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. Alternatively, you can enable 'database_replicated_allow_heavy_create' setting to allow this operation, use with caution. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1696: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc73dcc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:43.606977 [ 8101 ] {5ae0390e-1de8-4334-aea5-9b9f2f559189} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 717, line 717) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) - N as r FORMAT CSV;) 2025.06.13 15:47:43.615975 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:43.747553 [ 9642 ] {d0b4d49c-bee4-4b87-a57d-6cb00c4a5f16} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44574) (comment: 02317_distinct_in_order_optimization.sql) (query 5, line 5) (in query: CREATE TABLE distinct_in_order (`a` int) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 10, 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 = 501613489, compact_parts_max_bytes_to_buffer = 505124153, compact_parts_max_granules_to_buffer = 244, compact_parts_merge_max_bytes_to_prefetch_part = 18088047, merge_max_block_size = 6237, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 2385094471, vertical_merge_algorithm_min_rows_to_activate = 172551, vertical_merge_algorithm_min_columns_to_activate = 39, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 9503979, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 22, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 72525, primary_key_compress_block_size = 72342, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:43.776861 [ 9642 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:43.781756 [ 5978 ] {e601310b-6bd8-4f87-a426-f5ab198802f0} executeQuery: Code: 60. DB::Exception: Table test_11.test_readonly does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34790) (comment: 00543_access_to_temporary_table_in_readonly_mode.sh) (query 2, line 3) (in query: INSERT INTO test_readonly (ID) VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:209: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x000000002dcdb97b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1436: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a279f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:47:43.822966 [ 5978 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.test_readonly does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:209: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x000000002dcdb97b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1436: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a279f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:47:43.823220 [ 8101 ] {4e029dd1-b345-468c-9587-423131aa8ccc} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 718, line 718) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt16(1) - N as r FORMAT CSV;) 2025.06.13 15:47:43.831349 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:43.939088 [ 8101 ] {6596bf2c-80d3-491f-87d9-a2fabfb11229} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 719, line 719) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt16(1) - N as r FORMAT CSV;) 2025.06.13 15:47:43.954364 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:44.704689 [ 8430 ] {74b6b7fb-5fc9-403a-bcd1-7ed99a611316} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34848) (comment: 02771_log_faminy_truncate_count.sql) (query 2, line 2) (in query: CREATE TABLE test_log ( `crypto_name` String, `trade_date` Date ) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:44.737022 [ 8430 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:45.403362 [ 8430 ] {478aeb49-8420-4549-99e9-1afec6b7d685::all_9_10_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030c4f297 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3acc41 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 13. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1afd8 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 16. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 17. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 18. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 19. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:45.455511 [ 8430 ] {dca549ca-ae4f-4813-97f8-f5f962803a8b} executeQuery: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34912) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030c4f297 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3acc41 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 13. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1afd8 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 16. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 17. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 18. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 19. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:47:45.496059 [ 3894 ] {9ff852a7-3a85-40aa-a014-e4d18361a69f} 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.20286.altinityantalya (altinity build)) (from [::1]:34928) (comment: 03008_deduplication_remote_insert_select.sql) (query 2, line 3) (in query: CREATE TABLE src (`a` UInt64, `b` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/03008_deduplication_remote_insert_select/src', '{replica}') ORDER BY tuple() SETTINGS index_granularity = 15132, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 24, min_bytes_for_full_part_storage = 365035755, compact_parts_max_bytes_to_buffer = 128052728, compact_parts_max_granules_to_buffer = 131, compact_parts_merge_max_bytes_to_prefetch_part = 4259910, merge_max_block_size = 12649, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 6984889796, vertical_merge_algorithm_min_rows_to_activate = 489754, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 9429966, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 86, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 12592, primary_key_compress_block_size = 62147, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:45.502138 [ 8430 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030c4f297 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c3acc41 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 13. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1afd8 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 16. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 17. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 18. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 19. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:47:45.524863 [ 3894 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:45.690097 [ 8101 ] {a8b9c676-9060-4347-b504-47e0d2f66c01} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 727, line 727) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) - N as r FORMAT CSV;) 2025.06.13 15:47:45.704917 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:45.825285 [ 8101 ] {f038b7f1-2b89-4113-a53b-3b5e45f62c45} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 728, line 728) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt16(-1) - N as r FORMAT CSV;) 2025.06.13 15:47:45.847578 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:46.020153 [ 8101 ] {daf3624a-9fed-4897-87e0-4abafc7b4a06} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 729, line 729) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt16(-1) - N as r FORMAT CSV;) 2025.06.13 15:47:46.033199 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:46.700698 [ 3894 ] {b21699fe-9a3b-4c81-b4a4-2b11475e1158} 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.20286.altinityantalya (altinity build)) (from [::1]:34974) (comment: 03002_part_log_rmt_fetch_merge_error.sh) (query 3, line 5) (in query: CREATE TABLE rmt_master (`key` Int) ENGINE = ReplicatedMergeTree('/clickhouse/{database}', 'master') ORDER BY key SETTINGS always_fetch_merged_part = 0, old_parts_lifetime = 600, index_granularity = 26306, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 58, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 31912138, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 8127293, merge_max_block_size = 6040, 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 = 1373737345, index_granularity_bytes = 19400484, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 4, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 9195, primary_key_compress_block_size = 99912, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:46.719896 [ 3894 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:47.658557 [ 8101 ] {9d76d2f9-7210-40c5-b46c-fb0832e71338} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 737, line 737) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) - N as r FORMAT CSV;) 2025.06.13 15:47:47.670820 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:47.828951 [ 8101 ] {7832edd6-03ec-4191-b201-5c42fac2d206} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 738, line 738) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt32(1) - N as r FORMAT CSV;) 2025.06.13 15:47:47.868983 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:47.988663 [ 8101 ] {fb7e93e4-cf80-4c1c-b028-1d586ce1cdc7} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 739, line 739) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt32(1) - N as r FORMAT CSV;) 2025.06.13 15:47:48.011067 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:48.390967 [ 5110 ] {f84406c1-6697-44ce-94f3-8122198cfb2c} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1, line 1) (in query: SELECT BIT_AND([], [], []);) 2025.06.13 15:47:48.406746 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:48.567013 [ 7279 ] {478aeb49-8420-4549-99e9-1afec6b7d685::all_11_12_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:48.580795 [ 7279 ] {d8958315-114e-4be3-815d-4da778e52ff9} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35054) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:47:48.662428 [ 5110 ] {d9f641ef-6c83-4e8a-bfc2-160a03800bd9} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 2, line 2) (in query: SELECT BIT_OR([], [], []);) 2025.06.13 15:47:48.684965 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:48.704853 [ 4171 ] {1445e5ef-a0fc-454d-8cf9-07cc633ef5da} executeQuery: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35084) (comment: 02933_replicated_database_forbid_create_as_select.sh) (query 1, line 1) (in query: CREATE TABLE test_ni7k46pi_db.test2 (`id` UInt64) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 42655, min_bytes_for_wide_part = 228068770, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 8, min_bytes_for_full_part_storage = 432774541, compact_parts_max_bytes_to_buffer = 38726650, compact_parts_max_granules_to_buffer = 200, compact_parts_merge_max_bytes_to_prefetch_part = 12150615, merge_max_block_size = 15664, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3410725610, index_granularity_bytes = 13876232, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41516, primary_key_compress_block_size = 40475, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false AS SELECT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:48.738867 [ 4171 ] {} TCPHandler: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:48.741870 [ 7279 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:47:48.822800 [ 5110 ] {cadaa023-1dae-4e2e-b6b8-12ffb0c600c8} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 3, line 3) (in query: SELECT BIT_XOR([], [], []);) 2025.06.13 15:47:48.829973 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:49.080571 [ 5110 ] {07ae29f3-529a-4371-95ab-9a27a7bc9c81} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 4, line 4) (in query: SELECT BLAKE3([], [], []);) 2025.06.13 15:47:49.092507 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:49.281140 [ 5110 ] {5873495e-4fa6-4084-aac7-7aa54d7cbf8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 5, line 6) (in query: SELECT CHARACTER_LENGTH([], [], []);) 2025.06.13 15:47:49.298362 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:49.426623 [ 5110 ] {48d3254b-2547-4702-949f-91279bfafe1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 6, line 7) (in query: SELECT CHAR_LENGTH([], [], []);) 2025.06.13 15:47:49.440030 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:49.537376 [ 7279 ] {b00a5f53-96f6-4b31-acf9-fb0d44ec2945} executeQuery: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35098) (comment: 02933_replicated_database_forbid_create_as_select.sh) (query 1, line 1) (in query: CREATE TABLE test_ni7k46pi_db.test2 (`id` UInt64) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 42655, min_bytes_for_wide_part = 228068770, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 8, min_bytes_for_full_part_storage = 432774541, compact_parts_max_bytes_to_buffer = 38726650, compact_parts_max_granules_to_buffer = 200, compact_parts_merge_max_bytes_to_prefetch_part = 12150615, merge_max_block_size = 15664, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3410725610, index_granularity_bytes = 13876232, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41516, primary_key_compress_block_size = 40475, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false AS SELECT 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:49.581239 [ 7279 ] {} TCPHandler: Code: 344. DB::Exception: CREATE AS SELECT is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1703: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc741dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:47:49.666372 [ 5110 ] {7832a610-4257-4f2b-94d8-f1cfb0995133} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 7, line 8) (in query: SELECT COVAR_POP([], [], []);) 2025.06.13 15:47:49.675836 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:49.774497 [ 18602 ] {14f63d87-3b86-4bb5-8fe4-df0c6e76abf4} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35112) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: CREATE TABLE test_sort_proj (`x` UInt32, `y` UInt32, PROJECTION p (SELECT x, y ORDER BY y)) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.6051677465438843, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 477618891, compact_parts_max_bytes_to_buffer = 535372817, compact_parts_max_granules_to_buffer = 147, compact_parts_merge_max_bytes_to_prefetch_part = 24906321, merge_max_block_size = 2580, old_parts_lifetime = 162., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 66, min_merge_bytes_to_use_direct_io = 10737418240, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 74, 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 = 9723, primary_key_compress_block_size = 31086, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:49.787456 [ 8101 ] {673c84ca-7e8a-4b3d-85bb-9261039e45e8} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 747, line 747) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) - N as r FORMAT CSV;) 2025.06.13 15:47:49.787848 [ 18602 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:49.802228 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:49.832738 [ 5110 ] {cf0ed4a0-6dc0-4ff4-913c-97b9c986eeba} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 8, line 9) (in query: SELECT COVAR_SAMP([], [], []);) 2025.06.13 15:47:49.875368 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:49.970182 [ 8101 ] {71449748-b4b9-4383-9524-d01a6eb27df2} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 748, line 748) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt32(-1) - N as r FORMAT CSV;) 2025.06.13 15:47:49.983775 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:50.000607 [ 5110 ] {ae26a894-98b2-449e-8775-a8caae84f814} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 9, line 10) (in query: SELECT CRC32([], [], []);) 2025.06.13 15:47:50.053031 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:50.188092 [ 8101 ] {e218af7d-6a95-49a9-b9c1-cd4ec52459e6} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 749, line 749) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt32(-1) - N as r FORMAT CSV;) 2025.06.13 15:47:50.199042 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:50.200386 [ 5110 ] {631df4d2-cf4c-4393-9abb-544a6d1191df} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 10, line 11) (in query: SELECT CRC32IEEE([], [], []);) 2025.06.13 15:47:50.218238 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:50.328804 [ 7279 ] {c534f3c8-9dee-4713-9a4d-46db9daa8dd2} executeQuery: Code: 60. DB::Exception: Table test_11.test_sort_proj does not exist. Maybe you meant test_v0btabq2.test_sort_proj?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35152) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: insert into test_sort_proj select number, toUInt32(-number - 1) from numbers(100)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:50.360622 [ 5110 ] {30588738-e932-4c5d-9a1d-6da766fea9ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 11, line 12) (in query: SELECT CRC64([], [], []);) 2025.06.13 15:47:50.361497 [ 7279 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.test_sort_proj does not exist. Maybe you meant test_v0btabq2.test_sort_proj?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:47:50.370822 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:50.504093 [ 5110 ] {14ef71b8-c40c-4652-937d-7384d8685b84} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 12, line 13) (in query: SELECT DATABASE([], [], []);) 2025.06.13 15:47:50.532594 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:50.676708 [ 5110 ] {e00cb94f-e834-475e-9dab-7688e8422d39} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT DATE([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 13, line 14) (in query: SELECT DATE([], [], []);) 2025.06.13 15:47:50.687536 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT DATE([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:50.794900 [ 5110 ] {d3a13324-2114-42eb-86d9-f12ed84834f4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nothing): In scope SELECT dateDiff([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 14, line 15) (in query: SELECT DATE_DIFF([], [], []);) 2025.06.13 15:47:50.809150 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nothing): In scope SELECT dateDiff([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:50.832693 [ 2860 ] {41cc27da-ef19-45d6-a08d-d1aee20fd595} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 0. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35178) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE x < 10 order by x SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:50.880800 [ 2860 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:50.998503 [ 5110 ] {577411bd-8d9a-417b-be0a-466fcd25ed1e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT DATE_FORMAT([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 15, line 16) (in query: SELECT DATE_FORMAT([], [], []);) 2025.06.13 15:47:51.006071 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT DATE_FORMAT([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:51.117621 [ 5110 ] {cf881fbf-4889-4836-897a-cf0cee10887c} executeQuery: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT DATE_TRUNC([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 16, line 17) (in query: SELECT DATE_TRUNC([], [], []);) 2025.06.13 15:47:51.139198 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT DATE_TRUNC([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:51.280157 [ 5110 ] {d9391cf0-48ac-4044-9da5-90b1d1f51715} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT DAY([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 17, line 18) (in query: SELECT DAY([], [], []);) 2025.06.13 15:47:51.312143 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT DAY([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:51.439420 [ 2860 ] {ad38c5f2-7a26-4362-ad46-e83ca15badfc} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35212) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE x < 10 order by x SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:51.473287 [ 2860 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:51.497356 [ 5110 ] {6ce1c7ff-251d-49f9-957c-5f6ee86ef0e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT DAYOFMONTH([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 18, line 19) (in query: SELECT DAYOFMONTH([], [], []);) 2025.06.13 15:47:51.527979 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT DAYOFMONTH([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:51.722276 [ 5110 ] {7334114a-8401-429e-9c5e-3ec430b39558} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFWEEK([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 19, line 20) (in query: SELECT DAYOFWEEK([], [], []);) 2025.06.13 15:47:51.747057 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFWEEK([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:51.808681 [ 8101 ] {3b5b5118-0644-4bcf-8295-a11600bed920} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 757, line 757) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) - N as r FORMAT CSV;) 2025.06.13 15:47:51.822159 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:51.870532 [ 5110 ] {8c099010-1fef-48a7-9cfa-25ab81275ee9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT DAYOFYEAR([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 20, line 21) (in query: SELECT DAYOFYEAR([], [], []);) 2025.06.13 15:47:51.884804 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT DAYOFYEAR([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:51.897994 [ 9636 ] {6adb2863-3472-458f-9449-49c96044b696} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 0. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35230) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE x < 10 order by x SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:51.934134 [ 8101 ] {5e7a2ccf-d796-4e43-8307-ef79299cd6f7} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 758, line 758) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt64(1) - N as r FORMAT CSV;) 2025.06.13 15:47:51.937625 [ 9636 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:51.964188 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:51.975435 [ 5110 ] {cea6bb29-4c00-4c3f-aafd-1ac66e369556} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 21, line 22) (in query: SELECT FORMAT_BYTES([], [], []);) 2025.06.13 15:47:52.001546 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:52.124841 [ 8101 ] {8bc77a30-923e-4b34-8e0d-71e7f0a2171e} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 759, line 759) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt64(1) - N as r FORMAT CSV;) 2025.06.13 15:47:52.126856 [ 2860 ] {478aeb49-8420-4549-99e9-1afec6b7d685::all_13_14_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:52.133373 [ 5110 ] {9a02e5ad-046f-464c-a55e-6a57718280a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 22, line 23) (in query: SELECT FQDN([], [], []);) 2025.06.13 15:47:52.161124 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:52.167924 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:52.173367 [ 2860 ] {3db961fa-4723-4faf-bd9a-cc2537c4dcb0} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35240) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:47:52.203659 [ 2860 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x0000000030c1bcb1 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x0000000030c1b323 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 9. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 10. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 11. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 12. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 13. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:47:52.370583 [ 5110 ] {37a7de42-9c03-4257-951e-ee650c534121} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 23, line 24) (in query: SELECT FROM_BASE64([], [], []);) 2025.06.13 15:47:52.387089 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:52.502319 [ 4171 ] {74f9fca6-5015-4b2d-ae8b-5550c299b627} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35264) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE x < 10 order by x SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:52.518957 [ 5110 ] {fea850c9-3baf-4eb5-8c7d-4324beeb8881} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 24, line 25) (in query: SELECT FROM_DAYS([], [], []);) 2025.06.13 15:47:52.573953 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:52.628754 [ 4171 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:52.791556 [ 5110 ] {c538db36-bb83-45b1-ac61-c8ea237dcd98} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT FROM_UNIXTIME([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 25, line 26) (in query: SELECT FROM_UNIXTIME([], [], []);) 2025.06.13 15:47:52.817335 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT FROM_UNIXTIME([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:52.985004 [ 5110 ] {d7318ae1-c111-4efe-bc83-b3bca8eadd50} executeQuery: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 3, should be 1 or 2: In scope SELECT HOUR([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 26, line 27) (in query: SELECT HOUR([], [], []);) 2025.06.13 15:47:53.019083 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 3, should be 1 or 2: In scope SELECT HOUR([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:53.032944 [ 2860 ] {334db770-a6bc-4901-915e-b10c697f7545} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35294) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE x < 10 order by x FORMAT JSON SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:53.070719 [ 2860 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:53.155498 [ 5110 ] {5f432bd8-6db0-4772-968a-60a23247c89e} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 27, line 28) (in query: SELECT INET6_ATON([], [], []);) 2025.06.13 15:47:53.190811 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:53.240802 [ 18511 ] {68b41230-5056-4289-863e-d8beac70d3ca} executeQuery: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35014) (comment: 02433_default_expression_operator_in.sql) (query 11, line 31) (in query: -- Ensure that a table name cannot be passed to IN as string literal create table test (n int, m default n in 'default.table_name') engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:119: DB::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d6a3f3c 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:150: std::vector> DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x000000002d6a2709 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:365: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x000000002d688ed9 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1528: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000002d6a0707 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6940f6 13. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d683bed 14. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d647592 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d65f87f 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d65ff6e 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000302e7f2d 18. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000302e8990 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5b52e 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5e45a 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:47:53.258867 [ 18511 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:119: DB::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d6a3f3c 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:150: std::vector> DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x000000002d6a2709 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:365: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x000000002d688ed9 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1528: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000002d6a0707 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6940f6 13. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d683bed 14. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d647592 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d65f87f 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d65ff6e 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000302e7f2d 18. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000302e8990 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5b52e 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5e45a 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:47:53.359170 [ 5110 ] {42afdbb5-3808-48f4-8f10-935d8de3f781} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 28, line 29) (in query: SELECT INET6_NTOA([], [], []);) 2025.06.13 15:47:53.390434 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:53.414959 [ 18511 ] {271f69ed-531e-4273-aebe-aa154bfbedac} executeQuery: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35014) (comment: 02433_default_expression_operator_in.sql) (query 12, line 33) (in query: create table test (n int, m default in(n, 'default.table_name')) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:119: DB::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d6a3f3c 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:150: std::vector> DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x000000002d6a2709 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:365: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x000000002d688ed9 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1528: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000002d6a0707 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6940f6 13. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d683bed 14. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d647592 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d65f87f 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d65ff6e 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000302e7f2d 18. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000302e8990 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5b52e 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5e45a 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:47:53.445804 [ 18511 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'default.table_name' to type Int32: While processing n IN ('default.table_name') AS m: default expression and column type are incompatible. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x000000002e258e53 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:119: DB::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x000000002d6a3f3c 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:150: std::vector> DB::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x000000002d6a2709 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:365: DB::makeExplicitSet(DB::ASTFunction const*, DB::ActionsDAG const&, std::shared_ptr, DB::PreparedSets&) @ 0x000000002d688ed9 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1528: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000002d6a0707 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000002d6940f6 13. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002d683bed 14. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000002d647592 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002d65f87f 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002d65ff6e 17. ./build_docker/./src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000302e7f2d 18. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000302e8990 19. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5b52e 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5e45a 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:47:53.485875 [ 5110 ] {520e6612-6ba2-480d-8037-d8a28cd0db4d} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 29, line 30) (in query: SELECT INET_ATON([], [], []);) 2025.06.13 15:47:53.503356 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:53.656496 [ 5110 ] {a1a10bcd-5308-4081-bf5c-bf48030e84c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 30, line 31) (in query: SELECT INET_NTOA([], [], []);) 2025.06.13 15:47:53.679256 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:53.709668 [ 9636 ] {8b09aae7-046e-4579-850d-c9b49f2f1662} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60140) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE x < 10 order by x FORMAT JSON SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:53.736187 [ 9636 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:53.905051 [ 5110 ] {bf3d0ee1-9f00-486c-a67e-fb81cdefb975} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 31, line 32) (in query: SELECT IPv4CIDRToRange([], [], []);) 2025.06.13 15:47:53.917598 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:53.968278 [ 5110 ] {bc6eb2f1-d148-448b-86e3-ebd81292c552} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 32, line 33) (in query: SELECT IPv4NumToString([], [], []);) 2025.06.13 15:47:53.984168 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:53.991903 [ 8101 ] {8ff54a54-f46a-489e-b645-028059de6245} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 767, line 767) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) - N as r FORMAT CSV;) 2025.06.13 15:47:54.011936 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:54.097178 [ 5110 ] {cb732a63-47d1-4349-868f-e6448d9077d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 33, line 34) (in query: SELECT IPv4NumToStringClassC([], [], []);) 2025.06.13 15:47:54.112608 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:54.135648 [ 8101 ] {45c5a6be-3f9e-499d-a599-8c5ff1b1b628} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 768, line 768) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt64(-1) - N as r FORMAT CSV;) 2025.06.13 15:47:54.157270 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:54.263050 [ 5110 ] {96e65672-b326-42f8-a403-0256f94878df} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 34, line 35) (in query: SELECT IPv4StringToNum([], [], []);) 2025.06.13 15:47:54.272656 [ 8101 ] {66a08888-af73-4452-8b9f-65d66488706c} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 769, line 769) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt64(-1) - N as r FORMAT CSV;) 2025.06.13 15:47:54.298917 [ 6234 ] {11cc086d-fbde-427a-ba80-2fcaf631bc55} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60188) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE x < 10 order by x FORMAT JSON SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:54.302359 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:54.305280 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:54.317318 [ 6234 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:54.508306 [ 5110 ] {e025de70-9aed-4d4f-b027-04c928ed66ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 35, line 36) (in query: SELECT IPv4StringToNumOrDefault([], [], []);) 2025.06.13 15:47:54.516582 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:54.605260 [ 5110 ] {74713b30-3a4b-4b3c-90a3-01bfb789ab57} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 36, line 37) (in query: SELECT IPv4StringToNumOrNull([], [], []);) 2025.06.13 15:47:54.625352 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:54.707942 [ 5110 ] {5a54eb10-903b-4666-847b-6d82eebef5e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 37, line 38) (in query: SELECT IPv4ToIPv6([], [], []);) 2025.06.13 15:47:54.717685 [ 8101 ] {7c91df62-7b06-4d53-81d3-c43d4da7c87f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 772, line 772) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt8(1) as r FORMAT CSV;) 2025.06.13 15:47:54.726477 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:54.729469 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:54.853063 [ 2860 ] {3d160171-0568-46cd-813f-440652942e6e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60210) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE x < 10 order by x FORMAT JSON SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:54.881494 [ 2860 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE x < 10 ORDER BY x ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:54.891029 [ 5110 ] {9ed9e966-b392-4e7b-9fa3-781794ea693a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 38, line 39) (in query: SELECT IPv6CIDRToRange([], [], []);) 2025.06.13 15:47:54.909662 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:55.032362 [ 5110 ] {3d57c72b-38ac-419a-9be8-7c86ed9c2bad} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 39, line 40) (in query: SELECT IPv6NumToString([], [], []);) 2025.06.13 15:47:55.042646 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:55.073093 [ 7755 ] {a8831afa-ec33-4890-8fa6-653839e3671c} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60238) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:47:55.117787 [ 7755 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:1172: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de57e 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:47:55.220929 [ 5110 ] {8a89be42-6767-4eb1-9dfd-707e4e8d7296} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 40, line 41) (in query: SELECT IPv6StringToNum([], [], []);) 2025.06.13 15:47:55.238729 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:55.335224 [ 5110 ] {2a83ef3f-209f-4b82-b80d-247c8caeb9a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 41, line 42) (in query: SELECT IPv6StringToNumOrDefault([], [], []);) 2025.06.13 15:47:55.342894 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:55.375825 [ 7755 ] {526aaf35-b3a4-4bf8-8bdd-2aa55c402fa0} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 0. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60246) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE y > 4294967286 order by x SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:55.427518 [ 5110 ] {d4a66cdd-ec2c-412a-a159-145257c5e3ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 42, line 43) (in query: SELECT IPv6StringToNumOrNull([], [], []);) 2025.06.13 15:47:55.436047 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:55.451544 [ 7755 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:55.562659 [ 5110 ] {72f41f27-ef12-4c36-8d36-370318319c0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 43, line 44) (in query: SELECT JSONAllPaths([], [], []);) 2025.06.13 15:47:55.567102 [ 8101 ] {43491528-dbfb-4976-9789-85b8af915899} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 777, line 777) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) == N as r FORMAT CSV;) 2025.06.13 15:47:55.570786 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:55.574547 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:55.776305 [ 5110 ] {0bfd6be9-1eb5-403b-833b-2b7183a4537c} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 44, line 45) (in query: SELECT JSONAllPathsWithTypes([], [], []);) 2025.06.13 15:47:55.797688 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:55.898061 [ 5110 ] {2d8307d9-d310-458f-b08d-151aa1d02924} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 45, line 46) (in query: SELECT JSONArrayLength([], [], []);) 2025.06.13 15:47:55.915865 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:55.992100 [ 5110 ] {e34b8ec8-3bf6-4860-a90c-910d4b50ce55} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 46, line 47) (in query: SELECT JSONDynamicPaths([], [], []);) 2025.06.13 15:47:55.998826 [ 8432 ] {e3b65d66-3338-4904-856b-93be5577c12f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60286) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE y > 4294967286 order by x SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:56.028268 [ 8432 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:56.028288 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:56.163692 [ 5110 ] {89caf7d2-2da4-4746-91c8-06773d20d891} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 47, line 48) (in query: SELECT JSONDynamicPathsWithTypes([], [], []);) 2025.06.13 15:47:56.174739 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:56.304088 [ 5110 ] {6738146e-f8d8-43cc-a480-a9650f80b723} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: []: In scope SELECT JSONExtract([], [], []). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 48, line 49) (in query: SELECT JSONExtract([], [], []);) 2025.06.13 15:47:56.329415 [ 5110 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: []: In scope SELECT JSONExtract([], [], []). (ILLEGAL_COLUMN) 2025.06.13 15:47:56.559633 [ 5110 ] {3db162a4-2912-4b5b-9aa0-7478c0300131} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractArrayRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractArrayRaw([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 49, line 50) (in query: SELECT JSONExtractArrayRaw([], [], []);) 2025.06.13 15:47:56.560856 [ 8101 ] {7e8dc2fc-e0ef-42a1-8ac3-6c4275ba4cee} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 782, line 782) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt8(-1) as r FORMAT CSV;) 2025.06.13 15:47:56.568890 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:56.583409 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractArrayRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractArrayRaw([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:56.640968 [ 34302 ] {75346eb4-6a48-4e1e-a18c-290c172ca892} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 0. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60322) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE y > 4294967286 order by x SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:56.736824 [ 34302 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 0. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:56.798400 [ 5110 ] {631185b0-1d58-44f5-88db-7e3ac4aba6d8} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractBool should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractBool([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 50, line 51) (in query: SELECT JSONExtractBool([], [], []);) 2025.06.13 15:47:56.813237 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractBool should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractBool([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:56.884002 [ 5110 ] {cc7780fc-2b4a-4b56-9fc2-3e12fdb2fa55} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractFloat should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractFloat([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 51, line 52) (in query: SELECT JSONExtractFloat([], [], []);) 2025.06.13 15:47:56.895959 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractFloat should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractFloat([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:57.106836 [ 5110 ] {dab8d137-1667-439a-aba6-b6f322f0227b} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractInt should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractInt([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 52, line 53) (in query: SELECT JSONExtractInt([], [], []);) 2025.06.13 15:47:57.157752 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractInt should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractInt([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:57.301680 [ 5110 ] {2c2f7dc5-2299-4194-8057-006ffbfb303b} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractKeys should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractKeys([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 53, line 54) (in query: SELECT JSONExtractKeys([], [], []);) 2025.06.13 15:47:57.313344 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractKeys should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractKeys([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:57.347125 [ 34297 ] {dd67e713-566d-4b1d-8db4-10f435c8979f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60360) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE y > 4294967286 order by x SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:57.360904 [ 34297 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:57.437081 [ 5110 ] {6b948ced-d2cb-47e1-89f2-e88774f52b31} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: []: In scope SELECT JSONExtractKeysAndValues([], [], []). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 54, line 55) (in query: SELECT JSONExtractKeysAndValues([], [], []);) 2025.06.13 15:47:57.463889 [ 5110 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: []: In scope SELECT JSONExtractKeysAndValues([], [], []). (ILLEGAL_COLUMN) 2025.06.13 15:47:57.662659 [ 5110 ] {3d0b86ad-eadb-470a-b7a3-128dde3a49a2} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractKeysAndValuesRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractKeysAndValuesRaw([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 55, line 56) (in query: SELECT JSONExtractKeysAndValuesRaw([], [], []);) 2025.06.13 15:47:57.746331 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractKeysAndValuesRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractKeysAndValuesRaw([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:57.751082 [ 8101 ] {54620e50-8d2b-4919-81e1-3d4a080a1c42} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 787, line 787) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) == N as r FORMAT CSV;) 2025.06.13 15:47:57.758653 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:57.795625 [ 34297 ] {9097cd70-3bff-41f6-8058-0913e4653a77} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60364) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE y > 4294967286 order by x FORMAT JSON SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:57.812427 [ 34297 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:57.841033 [ 5110 ] {dbfcc4ed-b267-4590-a6d8-ba10f84e67d5} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractRaw([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 56, line 57) (in query: SELECT JSONExtractRaw([], [], []);) 2025.06.13 15:47:57.919172 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractRaw([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:58.056742 [ 34302 ] {478aeb49-8420-4549-99e9-1afec6b7d685::all_17_18_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:58.097692 [ 34302 ] {4451e317-8d14-458e-8c28-aca4ca0aa3d9} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60392) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:47:58.105917 [ 5110 ] {533da540-3a20-4e25-b507-c0570f30b822} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractString should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractString([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 57, line 58) (in query: SELECT JSONExtractString([], [], []);) 2025.06.13 15:47:58.128989 [ 34302 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:47:58.147854 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractString should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractString([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:58.254593 [ 5110 ] {88f5b251-af2e-4253-8223-638ad768ba16} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractUInt should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractUInt([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 58, line 59) (in query: SELECT JSONExtractUInt([], [], []);) 2025.06.13 15:47:58.282069 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractUInt should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractUInt([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:58.300251 [ 8432 ] {9f9e3857-48bb-470c-92cf-d0408b3d9930} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60396) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE y > 4294967286 order by x FORMAT JSON SETTINGS optimize_move_to_prewhere = 0, optimize_use_projections = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:58.326786 [ 8432 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:58.425803 [ 5110 ] {b575abb3-fed6-4323-af47-6b24b9ffc606} executeQuery: Code: 43. DB::Exception: The first argument of function JSONHas should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONHas([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 59, line 60) (in query: SELECT JSONHas([], [], []);) 2025.06.13 15:47:58.435099 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONHas should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONHas([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:58.584094 [ 5110 ] {2623cd8b-4f72-428b-9b5b-b45c5108a5ac} executeQuery: Code: 43. DB::Exception: The first argument of function JSONKey should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONKey([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 60, line 61) (in query: SELECT JSONKey([], [], []);) 2025.06.13 15:47:58.608541 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONKey should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONKey([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:58.730221 [ 5110 ] {33f3f55b-ad88-44e4-a9ff-47ac7f65186a} executeQuery: Code: 43. DB::Exception: The first argument of function JSONLength should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONLength([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 61, line 62) (in query: SELECT JSONLength([], [], []);) 2025.06.13 15:47:58.760156 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONLength should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONLength([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:58.812949 [ 34312 ] {99076eb1-c86e-4d0b-8daf-388c7d35b398} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60458) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE y > 4294967286 order by x FORMAT JSON SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:58.857094 [ 34312 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:58.872226 [ 8101 ] {b19f6f0c-a567-47e5-9f34-8d8d51128289} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 792, line 792) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt16(1) as r FORMAT CSV;) 2025.06.13 15:47:58.909118 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:58.916976 [ 5110 ] {663d41c8-82e8-4ab8-92d2-14d65fb18490} executeQuery: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT JSONMergePatch([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 62, line 63) (in query: SELECT JSONMergePatch([], [], []);) 2025.06.13 15:47:58.928613 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT JSONMergePatch([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:59.110164 [ 5110 ] {7a8f9681-9e95-4dc3-8778-9bdcaf2de70c} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 63, line 64) (in query: SELECT JSONSharedDataPaths([], [], []);) 2025.06.13 15:47:59.156679 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:59.275123 [ 19621 ] {} ExternalDictionariesLoader: Could not update external dictionary '61e0d5b5-88ca-4299-b8ed-7f0a0cbb8581', leaving the previous version, next update is scheduled at 2025-06-13 15:48:04: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f585dc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f5af07 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f54898 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f54302 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dd53bf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dcd2b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 30. DB::FlatDictionary::loadData() @ 0x0000000028a43c8b 31. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000028a434fb (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:47:59.312679 [ 5110 ] {f3397b8d-100a-4f82-8651-d64e8fa214c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 64, line 65) (in query: SELECT JSONSharedDataPathsWithTypes([], [], []);) 2025.06.13 15:47:59.354716 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:59.403069 [ 8442 ] {b6c37cc7-22f7-4467-a206-d3a675956afd} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60496) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT * FROM test_sort_proj WHERE y > 4294967286 order by x FORMAT JSON SETTINGS optimize_move_to_prewhere = 1, optimize_use_projections = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:59.432896 [ 8442 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT * FROM test_sort_proj WHERE y > 4294967286 ORDER BY x ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:47:59.523304 [ 5110 ] {7a120a5a-7d6b-4a35-9dd4-a98ef4ee2d6e} executeQuery: Code: 43. DB::Exception: The first argument of function JSONType should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONType([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 65, line 66) (in query: SELECT JSONType([], [], []);) 2025.06.13 15:47:59.559750 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONType should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONType([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:59.715562 [ 5110 ] {070888a8-e1d2-40fb-b990-b6852f72b29e} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 66, line 67) (in query: SELECT JSON_ARRAY_LENGTH([], [], []);) 2025.06.13 15:47:59.737898 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:47:59.800647 [ 8101 ] {0dde734c-5d14-4372-9bd0-11be7243c810} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 797, line 797) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) == N as r FORMAT CSV;) 2025.06.13 15:47:59.805801 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:47:59.967429 [ 5110 ] {fd97cb3f-ea28-49c8-8adc-18381cebc8c2} executeQuery: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nothing): In scope SELECT JSON_EXISTS([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 67, line 68) (in query: SELECT JSON_EXISTS([], [], []);) 2025.06.13 15:48:00.008478 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nothing): In scope SELECT JSON_EXISTS([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:00.189488 [ 5110 ] {9caa4a96-495e-4747-99d0-667d50ca248e} executeQuery: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nothing): In scope SELECT JSON_QUERY([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 68, line 69) (in query: SELECT JSON_QUERY([], [], []);) 2025.06.13 15:48:00.220849 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nothing): In scope SELECT JSON_QUERY([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:00.373888 [ 34312 ] {17ffe67b-dc67-41c7-bcf7-e7f758f1cda2} executeQuery: Code: 60. DB::Exception: Table test_11.test_sort_proj does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60546) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: ALTER TABLE test_sort_proj DELETE WHERE x % 2 = 0 SETTINGS mutations_sync=2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7949c6 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c794127 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3fe6f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:00.384195 [ 5110 ] {cde952ba-3e86-4db6-9c04-0b8587f34597} executeQuery: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nothing): In scope SELECT JSON_VALUE([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 69, line 70) (in query: SELECT JSON_VALUE([], [], []);) 2025.06.13 15:48:00.400318 [ 34312 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.test_sort_proj does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2031: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002c7949c6 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2057: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c794127 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3fe6f 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:00.466693 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nothing): In scope SELECT JSON_VALUE([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:00.653517 [ 5110 ] {dcc4019b-c920-4128-ae44-b45db0c43b1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 70, line 71) (in query: SELECT L1Distance([], [], []);) 2025.06.13 15:48:00.666991 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:00.764956 [ 5110 ] {5ea9e302-721c-486a-9200-3fbe46336e71} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 71, line 72) (in query: SELECT L1Norm([], [], []);) 2025.06.13 15:48:00.777213 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:00.819858 [ 8101 ] {9549fd59-464c-492b-9540-fb944425ab1e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 802, line 802) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt16(-1) as r FORMAT CSV;) 2025.06.13 15:48:00.840345 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:00.904591 [ 5110 ] {9762f232-68b3-4e4f-a684-3765a6bdd474} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 72, line 73) (in query: SELECT L1Normalize([], [], []);) 2025.06.13 15:48:00.905792 [ 34302 ] {64bef55d-b63f-42d2-9936-6a9d42aaf4e1} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT count() FROM test_sort_proj. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60630) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: SELECT count() from test_sort_proj;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:00.924130 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:00.935885 [ 34302 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_sort_proj' in scope SELECT count() FROM test_sort_proj. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:00.998728 [ 5110 ] {de088e5d-e592-4410-bb6e-aa54a15e208e} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 73, line 74) (in query: SELECT L2Distance([], [], []);) 2025.06.13 15:48:01.009573 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:01.210328 [ 5110 ] {78a7acf5-20b8-4de9-ba7f-f531c1ce8206} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 74, line 75) (in query: SELECT L2Norm([], [], []);) 2025.06.13 15:48:01.223354 [ 34313 ] {478aeb49-8420-4549-99e9-1afec6b7d685::all_19_20_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:01.236130 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:01.241485 [ 34313 ] {922dadd8-d1d3-4818-8381-d662ffdaa1bc} executeQuery: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60662) (comment: 01442_merge_detach_attach_long.sh) (query 1, line 1) (in query: OPTIMIZE TABLE t FINAL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:48:01.258148 [ 34313 ] {} TCPHandler: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x0000000030bff197 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:363: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c00f51 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 10. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x00000000311de154 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e97c4 12. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:48:01.347143 [ 5110 ] {b6ad987e-8ffd-466f-a6b7-eee8841c8703} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 75, line 76) (in query: SELECT L2Normalize([], [], []);) 2025.06.13 15:48:01.355439 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:01.496654 [ 5110 ] {3629e3d5-6fa5-4af9-bba4-d5fdcd85bb01} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 76, line 77) (in query: SELECT L2SquaredDistance([], [], []);) 2025.06.13 15:48:01.510485 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:01.652967 [ 34313 ] {c55fe6eb-1d3a-417d-b7c6-976630227e28} executeQuery: Code: 60. DB::Exception: Table test_11.test_sort_proj does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60684) (comment: 01710_normal_projections.sh) (query 1, line 1) (in query: DROP TABLE test_sort_proj), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:01.660281 [ 5110 ] {e48685c4-af05-42c5-b788-0e2bb9066aab} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 77, line 78) (in query: SELECT L2SquaredNorm([], [], []);) 2025.06.13 15:48:01.701523 [ 34313 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.test_sort_proj does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:01.783016 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:01.859126 [ 8101 ] {8965cc59-51be-4ba2-aec9-a3e1e1e09f71} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 807, line 807) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) == N as r FORMAT CSV;) 2025.06.13 15:48:01.867748 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:01.879724 [ 5110 ] {bb7c64f2-bbc1-447d-9040-cbc1141c7973} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT LAST_DAY([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 78, line 79) (in query: SELECT LAST_DAY([], [], []);) 2025.06.13 15:48:01.889734 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT LAST_DAY([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:02.005252 [ 5110 ] {7d5c0dc2-af9f-4568-a0f0-e3119bcb6838} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 79, line 80) (in query: SELECT LinfDistance([], [], []);) 2025.06.13 15:48:02.022597 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:02.155388 [ 5110 ] {c93f4aaa-89a6-4687-be1f-5196084edf2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 80, line 81) (in query: SELECT LinfNorm([], [], []);) 2025.06.13 15:48:02.202114 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:02.377682 [ 5110 ] {2eb59845-b4b6-423a-9c1a-0f1d33c01724} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 81, line 82) (in query: SELECT LinfNormalize([], [], []);) 2025.06.13 15:48:02.411153 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:02.614779 [ 5110 ] {545b9bc8-7fff-4d07-83bc-6df0ce75b1d0} executeQuery: Code: 43. DB::Exception: Arguments of function arrayLpDistance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT LpDistance([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 82, line 83) (in query: SELECT LpDistance([], [], []);) 2025.06.13 15:48:02.647604 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayLpDistance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT LpDistance([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:02.810809 [ 8101 ] {870372ec-49e4-4acb-901b-ffb7c9c01103} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 812, line 812) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt32(1) as r FORMAT CSV;) 2025.06.13 15:48:02.840523 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:02.862109 [ 5110 ] {cdac897d-020b-48f3-b568-395f76a3a741} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 83, line 84) (in query: SELECT LpNorm([], [], []);) 2025.06.13 15:48:02.881569 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:03.055083 [ 5110 ] {7e0fee15-bb36-43cb-9440-3f7543e680b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 84, line 85) (in query: SELECT LpNormalize([], [], []);) 2025.06.13 15:48:03.100694 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:03.193808 [ 3895 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:03.195283 [ 3895 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:03.227042 [ 5110 ] {e63c1d9d-7ca1-4154-afef-752b016c803f} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 85, line 86) (in query: SELECT MACNumToString([], [], []);) 2025.06.13 15:48:03.238472 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:03.341360 [ 5110 ] {00dce54c-4977-45f2-b815-2149d4c6a96a} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 86, line 87) (in query: SELECT MACStringToNum([], [], []);) 2025.06.13 15:48:03.371043 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:03.449997 [ 5110 ] {7dfd5e7e-08a9-489f-bf4c-f9468dae4cde} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 87, line 88) (in query: SELECT MACStringToOUI([], [], []);) 2025.06.13 15:48:03.455675 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:03.634217 [ 5110 ] {4b0fc9c1-5dd7-4cc2-a5f7-eaa86bfe6a93} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 88, line 89) (in query: SELECT MAP_FROM_ARRAYS([], [], []);) 2025.06.13 15:48:03.666382 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:03.747889 [ 5112 ] {} TCPHandler: TCPHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_rlxznkrm` for 3155695200s has been exceeded: failed_sequential_authentications = 2/1. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_rlxznkrm`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::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&&) @ 0x000000002bdae137 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdadf07 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdad381 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdabf12 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdabe9b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbf804 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:03.754932 [ 5112 ] {} ServerErrorHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_rlxznkrm` for 3155695200s has been exceeded: failed_sequential_authentications = 2/1. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_rlxznkrm`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::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&&) @ 0x000000002bdae137 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdadf07 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdad381 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdabf12 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdabe9b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbf804 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:03.807999 [ 8101 ] {81db52ba-7220-4606-a7d6-ce6cc8f2ed55} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 817, line 817) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) == N as r FORMAT CSV;) 2025.06.13 15:48:03.810971 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:03.859574 [ 5110 ] {0a597b8a-5a73-435f-b04f-953147506b85} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 89, line 90) (in query: SELECT MD4([], [], []);) 2025.06.13 15:48:03.893257 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:04.081967 [ 5110 ] {ae97828a-dad0-4563-a0c5-c7579479b200} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 90, line 91) (in query: SELECT MD5([], [], []);) 2025.06.13 15:48:04.110968 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:04.275037 [ 5110 ] {11a5a36f-7a07-4afb-b2e4-d36d2ce3db3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT MILLISECOND([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 91, line 92) (in query: SELECT MILLISECOND([], [], []);) 2025.06.13 15:48:04.289913 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT MILLISECOND([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:04.373693 [ 5110 ] {a2ecc236-044c-4640-a03d-41f05efc87e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT MINUTE([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 92, line 93) (in query: SELECT MINUTE([], [], []);) 2025.06.13 15:48:04.399362 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT MINUTE([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:04.518033 [ 5110 ] {200e4f65-75e7-4c1f-a6a9-ebadc3f8160a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT MONTH([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 93, line 94) (in query: SELECT MONTH([], [], []);) 2025.06.13 15:48:04.538621 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT MONTH([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:04.633355 [ 8101 ] {a6846860-5993-4b4d-b63f-aae2e74b37c8} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 822, line 822) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt32(-1) as r FORMAT CSV;) 2025.06.13 15:48:04.645536 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:04.691317 [ 5110 ] {b19a48ce-a861-41ae-bf41-af2170f6a299} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 94, line 95) (in query: SELECT OCTET_LENGTH([], [], []);) 2025.06.13 15:48:04.708667 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:04.831718 [ 5110 ] {eb564c2e-b98e-4362-92bb-c2c1b4f3760c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT QUARTER([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 95, line 96) (in query: SELECT QUARTER([], [], []);) 2025.06.13 15:48:04.837334 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT QUARTER([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:05.052557 [ 5110 ] {7b436c2f-0534-4aed-ac22-8ae93ee357cb} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nothing): In scope SELECT REGEXP_EXTRACT([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 96, line 97) (in query: SELECT REGEXP_EXTRACT([], [], []);) 2025.06.13 15:48:05.094881 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nothing): In scope SELECT REGEXP_EXTRACT([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:05.224895 [ 5110 ] {6ecf0d85-08c2-487f-83bf-f454acd91e6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 97, line 98) (in query: SELECT REGEXP_MATCHES([], [], []);) 2025.06.13 15:48:05.273629 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:05.428909 [ 5110 ] {1defaef5-19d6-4438-a7cd-76a69489580a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpAll'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT REGEXP_REPLACE([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 98, line 99) (in query: SELECT REGEXP_REPLACE([], [], []);) 2025.06.13 15:48:05.440999 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpAll'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT REGEXP_REPLACE([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:05.559030 [ 8101 ] {1a94c18f-753b-45a0-b5f4-7cbb6bdb86b1} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 827, line 827) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) == N as r FORMAT CSV;) 2025.06.13 15:48:05.585030 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:05.592803 [ 5110 ] {33aff4f7-fdb7-439a-a58e-ed998823573f} executeQuery: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 3, should be 1: In scope SELECT RIPEMD160([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 99, line 100) (in query: SELECT RIPEMD160([], [], []);) 2025.06.13 15:48:05.628067 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 3, should be 1: In scope SELECT RIPEMD160([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:05.748372 [ 5110 ] {95118423-08d5-4af9-a3fd-6982116e0a3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 100, line 101) (in query: SELECT SCHEMA([], [], []);) 2025.06.13 15:48:05.811107 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:05.900392 [ 5110 ] {2f667b7e-73cb-4b16-a881-4d6ec43af1f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT SECOND([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 101, line 102) (in query: SELECT SECOND([], [], []);) 2025.06.13 15:48:05.918458 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT SECOND([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:06.026936 [ 5110 ] {f6b7774c-1cd3-4610-a84d-8b04466046d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 102, line 103) (in query: SELECT SHA1([], [], []);) 2025.06.13 15:48:06.047087 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:06.184832 [ 5110 ] {d371ad16-d195-4f0b-b393-ad4d5929ac55} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 103, line 104) (in query: SELECT SHA224([], [], []);) 2025.06.13 15:48:06.207087 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:06.328337 [ 5110 ] {923857c7-fba4-4a98-9564-4104be996221} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 104, line 105) (in query: SELECT SHA256([], [], []);) 2025.06.13 15:48:06.359919 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:06.459017 [ 5112 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:06.460904 [ 5112 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:06.495850 [ 5110 ] {2bfeaa30-3dc4-4f39-9c57-722801fb38dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 105, line 106) (in query: SELECT SHA384([], [], []);) 2025.06.13 15:48:06.514872 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:06.553300 [ 9642 ] {19a88d9d-f396-4d5e-b5f6-285044d0ec78} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50772) (comment: 02907_backup_restore_flatten_nested.sh) (query 3, line 4) (in query: create table test (test Array(Tuple(foo String, bar Float64))) ENGINE = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:06.563583 [ 9642 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:06.656240 [ 5110 ] {0129f4c7-771d-4f7a-86a0-0b8c9a3cb711} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 106, line 107) (in query: SELECT SHA512([], [], []);) 2025.06.13 15:48:06.682349 [ 8101 ] {ffd79513-ab6d-4911-abc3-b7130dd2bfbb} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 832, line 832) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt64(1) as r FORMAT CSV;) 2025.06.13 15:48:06.685635 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:06.688851 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:06.734698 [ 34313 ] {25139a90-7c25-46b5-a41d-cdc00685fae7} 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.20286.altinityantalya (altinity build)) (from [::1]:60766) (comment: 01380_nullable_state.sql) (query 15, line 15) (in query: SELECT k, finalizeAggregation(uniqState(x)) FROM (SELECT intDiv(number, 3) AS k, toNullable(1) AS x FROM system.numbers LIMIT 100000) GROUP BY k WITH TOTALS ORDER BY k LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:48:06.807047 [ 5110 ] {05586420-565d-4373-8cc8-0661d05de308} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 107, line 108) (in query: SELECT SHA512_256([], [], []);) 2025.06.13 15:48:06.812130 [ 3895 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:06.875328 [ 3895 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:06.884863 [ 34313 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:48:06.918436 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:07.061785 [ 5110 ] {418c7e92-7a90-4166-821d-0e91600f4956} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 108, line 109) (in query: SELECT STD([], [], []);) 2025.06.13 15:48:07.072423 [ 5978 ] {6ffbe7cb-4938-4e2a-aab2-509d2cfad878} executeQuery: Code: 390. DB::Exception: Table `test` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50830) (comment: 02907_backup_restore_flatten_nested.sh) (query 1, line 1) (in query: show create table test), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002c725068 6. ./src/Databases/IDatabase.h:350: DB::IDatabase::getCreateTableQuery(String const&, std::shared_ptr) const @ 0x000000002c029e21 7. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:66: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000002e32b399 8. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x000000002e32abcc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:48:07.082187 [ 5978 ] {} TCPHandler: Code: 390. DB::Exception: Table `test` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002c725068 6. ./src/Databases/IDatabase.h:350: DB::IDatabase::getCreateTableQuery(String const&, std::shared_ptr) const @ 0x000000002c029e21 7. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:66: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000002e32b399 8. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x000000002e32abcc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:48:07.112020 [ 6193 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:07.114100 [ 6193 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:07.119125 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:07.221922 [ 5110 ] {75b9ff76-b4c6-4735-b330-f0a93f94181f} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 109, line 110) (in query: SELECT STDDEV_POP([], [], []);) 2025.06.13 15:48:07.254047 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:07.370952 [ 5110 ] {db43463a-b4fa-44ac-9b6e-3bc79a1654d8} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 110, line 111) (in query: SELECT STDDEV_SAMP([], [], []);) 2025.06.13 15:48:07.387851 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:07.431095 [ 5112 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:07.435005 [ 5112 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:07.492461 [ 5110 ] {a8f636a0-5b85-4b7b-931d-1db228ba388d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substringIndex, String expected: In scope SELECT SUBSTRING_INDEX([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 111, line 112) (in query: SELECT SUBSTRING_INDEX([], [], []);) 2025.06.13 15:48:07.500042 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substringIndex, String expected: In scope SELECT SUBSTRING_INDEX([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:07.599993 [ 5110 ] {471912e6-0b9e-4c0e-a8b0-d1b5df35f29a} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT SVG([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 112, line 113) (in query: SELECT SVG([], [], []);) 2025.06.13 15:48:07.629610 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT SVG([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:07.693850 [ 8101 ] {195ab6fa-e894-470c-95c1-c176f7eb32cb} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 837, line 837) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) == N as r FORMAT CSV;) 2025.06.13 15:48:07.723376 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:07.748100 [ 3894 ] {} TCPHandler: TCPHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_rlxznkrm` for 3155695200s has been exceeded: failed_sequential_authentications = 5/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_rlxznkrm`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::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&&) @ 0x000000002bdae137 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdadf07 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdad381 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdabf12 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdabe9b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbf804 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:07.749290 [ 3894 ] {} ServerErrorHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_rlxznkrm` for 3155695200s has been exceeded: failed_sequential_authentications = 5/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_rlxznkrm`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::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&&) @ 0x000000002bdae137 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdadf07 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdad381 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdabf12 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdabe9b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbf804 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:07.828034 [ 5110 ] {47779254-83fc-4ec7-85d4-196809a71803} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nothing): In scope SELECT dateDiff([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 113, line 114) (in query: SELECT TIMESTAMP_DIFF([], [], []);) 2025.06.13 15:48:07.840166 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nothing): In scope SELECT dateDiff([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:07.993426 [ 5110 ] {fcf4992d-052b-4b06-9d0c-c5312f4f5cce} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 114, line 115) (in query: SELECT TO_BASE64([], [], []);) 2025.06.13 15:48:08.007254 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:08.073339 [ 4172 ] {8cc401af-7011-4525-a359-c61c547f82e7} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50878) (comment: 02907_backup_restore_flatten_nested.sh) (query 3, line 4) (in query: create table test2 (test Nested(foo String, bar Float64)) ENGINE = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:08.076964 [ 8430 ] {} TCPHandler: TCPHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_rlxznkrm` for 3155695200s has been exceeded: failed_sequential_authentications = 6/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_rlxznkrm`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::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&&) @ 0x000000002bdae137 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdadf07 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdad381 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdabf12 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdabe9b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbf804 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:08.077918 [ 8430 ] {} ServerErrorHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_rlxznkrm` for 3155695200s has been exceeded: failed_sequential_authentications = 6/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_rlxznkrm`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::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&&) @ 0x000000002bdae137 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdadf07 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdad381 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdabf12 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdabe9b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbf804 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:08.089225 [ 4172 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:08.119012 [ 5110 ] {66ca29ea-7c66-4711-98e4-78d053613aca} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 3, should be 1 or 2: In scope SELECT TO_DAYS([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 115, line 116) (in query: SELECT TO_DAYS([], [], []);) 2025.06.13 15:48:08.141885 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 3, should be 1 or 2: In scope SELECT TO_DAYS([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:08.282833 [ 5110 ] {e58a7a5e-1d65-446f-8e2a-38ae4f03256a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nothing): In scope SELECT TO_UNIXTIME([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 116, line 117) (in query: SELECT TO_UNIXTIME([], [], []);) 2025.06.13 15:48:08.310032 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nothing): In scope SELECT TO_UNIXTIME([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:08.333035 [ 8430 ] {8313bf44-2202-428b-ae93-8bf4a9d97db8} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_gl0qamjw.test_constraints (a30f9b93-565e-4070-b962-be6160cbb867) is violated at row 1. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50942) (comment: 00953_constraints_operations.sh) (query 1, line 1) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5e9077 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031da1148 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:08.349861 [ 8430 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_gl0qamjw.test_constraints (a30f9b93-565e-4070-b962-be6160cbb867) is violated at row 1. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5e9077 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031da1148 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:08.412091 [ 5110 ] {79e19e85-836c-4732-872f-ed31070ac2e0} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function ULIDStringToDateTime: should be 1 or 2: In scope SELECT ULIDStringToDateTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 117, line 118) (in query: SELECT ULIDStringToDateTime([], [], []);) 2025.06.13 15:48:08.436881 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function ULIDStringToDateTime: should be 1 or 2: In scope SELECT ULIDStringToDateTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:08.540447 [ 5110 ] {bacec3a3-ef58-4b8f-9f45-2ad0a6793a76} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHash doesn't match: passed 3, should be 1 or 2.: In scope SELECT URLHash([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 118, line 119) (in query: SELECT URLHash([], [], []);) 2025.06.13 15:48:08.571366 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHash doesn't match: passed 3, should be 1 or 2.: In scope SELECT URLHash([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:08.572436 [ 18602 ] {74d42bb0-d7ae-413c-ba68-2b50ce4c5507} executeQuery: Code: 390. DB::Exception: Table `test2` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50948) (comment: 02907_backup_restore_flatten_nested.sh) (query 1, line 1) (in query: show create table test2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002c725068 6. ./src/Databases/IDatabase.h:350: DB::IDatabase::getCreateTableQuery(String const&, std::shared_ptr) const @ 0x000000002c029e21 7. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:66: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000002e32b399 8. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x000000002e32abcc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:48:08.592304 [ 18602 ] {} TCPHandler: Code: 390. DB::Exception: Table `test2` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002c725068 6. ./src/Databases/IDatabase.h:350: DB::IDatabase::getCreateTableQuery(String const&, std::shared_ptr) const @ 0x000000002c029e21 7. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:66: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000002e32b399 8. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x000000002e32abcc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:48:08.648435 [ 8101 ] {9a9bd55b-ff9a-49a1-9161-dfc8c0f7de21} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 842, line 842) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt64(-1) as r FORMAT CSV;) 2025.06.13 15:48:08.661555 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:08.701694 [ 5110 ] {65f25eb3-bb43-4f1c-be9a-a527c58ff1e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 119, line 120) (in query: SELECT URLHierarchy([], [], []);) 2025.06.13 15:48:08.745974 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:08.892933 [ 5110 ] {5c06dc6c-638b-4027-96f0-c7e111e6a7ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 120, line 121) (in query: SELECT URLPathHierarchy([], [], []);) 2025.06.13 15:48:09.007538 [ 18377 ] {23af4913-197a-4b75-86fd-1eb06476830c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49734) (comment: 01416_join_totals_header_bug.sql) (in query: DROP DATABASE IF EXISTS test_fvkzvyxc SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:48:09.022678 [ 18377 ] {23af4913-197a-4b75-86fd-1eb06476830c} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:09.058917 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:09.196483 [ 8430 ] {747b842d-94dd-4d0b-a093-13033abc9880} executeQuery: Code: 60. DB::Exception: Table test_11.test does not exist. Maybe you meant test_1.test?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50978) (comment: 02907_backup_restore_flatten_nested.sh) (query 1, line 2) (in query: drop table test sync;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:09.204865 [ 5110 ] {e8f1136e-d972-4988-98a5-9cab143f7738} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 121, line 122) (in query: SELECT UTCTimestamp([], [], []);) 2025.06.13 15:48:09.212304 [ 8430 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.test does not exist. Maybe you meant test_1.test?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:09.223153 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:09.308746 [ 5163 ] {4de72ce5-32d2-40e4-af5e-2870eae7093d} executeQuery: Code: 36. DB::Exception: No such attribute 'prefixprefixprefixprefix': In scope SELECT '127.0.0.0/24' = dictGetString(concat('test_15', '.dict_ipv4_trie'), 'prefixprefixprefixprefix', tuple(IPv4StringToNumOrDefault('127.0.0.0127.0.0.0'))). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50694) (comment: 01018_ip_dictionary_long.sql) (query 13, line 44) (in query: SELECT '127.0.0.0/24' = dictGetString(concat('test_15', '.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:176: DB::DictionaryStructure::getAttribute(String const&) const @ 0x000000002ace2016 6. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017f457f8 7. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f7d167 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:48:09.320484 [ 5163 ] {} TCPHandler: Code: 36. DB::Exception: No such attribute 'prefixprefixprefixprefix': In scope SELECT '127.0.0.0/24' = dictGetString(concat('test_15', '.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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:176: DB::DictionaryStructure::getAttribute(String const&) const @ 0x000000002ace2016 6. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017f457f8 7. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f7d167 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:48:09.469083 [ 5110 ] {b0185d43-a757-41af-bf2e-61b1c5b9336f} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 122, line 123) (in query: SELECT UTC_timestamp([], [], []);) 2025.06.13 15:48:09.481794 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:09.592051 [ 8101 ] {65bb86ed-8ee6-4475-9e5d-23cfe8c3e915} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 847, line 847) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) == N as r FORMAT CSV;) 2025.06.13 15:48:09.592644 [ 5110 ] {d114b943-a023-4a2a-9500-86a2d00284ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDNumToString doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDNumToString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 123, line 124) (in query: SELECT UUIDNumToString([], [], []);) 2025.06.13 15:48:09.612196 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:09.617747 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDNumToString doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDNumToString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:09.746538 [ 5110 ] {3d9a314c-b05f-4633-9a8c-08aaa35b7042} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDStringToNum doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDStringToNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 124, line 125) (in query: SELECT UUIDStringToNum([], [], []);) 2025.06.13 15:48:09.753789 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDStringToNum doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDStringToNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:09.833698 [ 18377 ] {393e3f0a-d9d8-4884-bac7-058babe5b6b1} executeQuery: Code: 390. DB::Exception: Table `test` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51024) (comment: 02907_backup_restore_flatten_nested.sh) (query 1, line 1) (in query: show create table test), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002c725068 6. ./src/Databases/IDatabase.h:350: DB::IDatabase::getCreateTableQuery(String const&, std::shared_ptr) const @ 0x000000002c029e21 7. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:66: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000002e32b399 8. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x000000002e32abcc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:48:09.853510 [ 18377 ] {} TCPHandler: Code: 390. DB::Exception: Table `test` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002c725068 6. ./src/Databases/IDatabase.h:350: DB::IDatabase::getCreateTableQuery(String const&, std::shared_ptr) const @ 0x000000002c029e21 7. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:66: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000002e32b399 8. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x000000002e32abcc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:48:09.948441 [ 5110 ] {9601faba-4720-4fa2-956b-f9f3f83fe993} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDToNum doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDToNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 125, line 126) (in query: SELECT UUIDToNum([], [], []);) 2025.06.13 15:48:09.954990 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDToNum doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDToNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:10.061772 [ 5110 ] {431aaf0c-f366-48ad-bbfd-bc5b2ce159cf} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function UUIDv7ToDateTime: should be 1 or 2: In scope SELECT UUIDv7ToDateTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 126, line 127) (in query: SELECT UUIDv7ToDateTime([], [], []);) 2025.06.13 15:48:10.079252 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function UUIDv7ToDateTime: should be 1 or 2: In scope SELECT UUIDv7ToDateTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:10.216091 [ 5110 ] {49f3792a-93cf-4c48-88f9-904b6b1df9ff} executeQuery: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 127, line 128) (in query: SELECT VAR_POP([], [], []);) 2025.06.13 15:48:10.237906 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:10.341788 [ 5110 ] {34cc4583-bbfc-4601-aca7-26a78bf5d935} executeQuery: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 128, line 129) (in query: SELECT VAR_SAMP([], [], []);) 2025.06.13 15:48:10.391975 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:10.396335 [ 3894 ] {77e22d58-e999-4ec4-80ad-301290c7882b} executeQuery: Code: 60. DB::Exception: Table test_11.test2 does not exist. Maybe you meant test_1.test?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51068) (comment: 02907_backup_restore_flatten_nested.sh) (query 1, line 2) (in query: drop table test2 sync;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:10.428490 [ 3894 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.test2 does not exist. Maybe you meant test_1.test?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:10.486291 [ 5110 ] {1ec09c68-c0b7-4ce8-b54b-be06a65a23c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 3, should be 1 or 2: In scope SELECT YEAR([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 129, line 130) (in query: SELECT YEAR([], [], []);) 2025.06.13 15:48:10.504927 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 3, should be 1 or 2: In scope SELECT YEAR([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:10.619997 [ 8101 ] {c28577f0-d5d1-4318-9b35-5f4781859f7c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 852, line 852) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt8(1) as r FORMAT CSV;) 2025.06.13 15:48:10.635111 [ 5110 ] {76886d8a-fb08-456c-bd9c-ab278ccc6c18} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 130, line 131) (in query: SELECT YYYYMMDDToDate([], [], []);) 2025.06.13 15:48:10.647954 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:10.647992 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:10.847948 [ 5110 ] {e3aea030-de0a-4acc-96cd-99225b4f414d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 131, line 132) (in query: SELECT YYYYMMDDToDate32([], [], []);) 2025.06.13 15:48:10.863994 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:10.925213 [ 5005 ] {c5bcc77c-d8cc-435d-a0e9-749c7f5e5a2e} executeQuery: Code: 390. DB::Exception: Table `test2` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51138) (comment: 02907_backup_restore_flatten_nested.sh) (query 1, line 1) (in query: show create table test2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002c725068 6. ./src/Databases/IDatabase.h:350: DB::IDatabase::getCreateTableQuery(String const&, std::shared_ptr) const @ 0x000000002c029e21 7. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:66: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000002e32b399 8. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x000000002e32abcc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:48:10.974279 [ 5005 ] {} TCPHandler: Code: 390. DB::Exception: Table `test2` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002c725068 6. ./src/Databases/IDatabase.h:350: DB::IDatabase::getCreateTableQuery(String const&, std::shared_ptr) const @ 0x000000002c029e21 7. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:66: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000002e32b399 8. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x000000002e32abcc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:48:11.014064 [ 5110 ] {66631d11-890d-4f16-a4f2-d88c57994b09} 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([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 132, line 133) (in query: SELECT YYYYMMDDhhmmssToDateTime([], [], []);) 2025.06.13 15:48:11.041343 [ 5110 ] {} 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([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:11.123208 [ 5110 ] {7d78af2a-dc65-484b-9aac-95805b00ecc3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Array(Nothing): In scope SELECT YYYYMMDDhhmmssToDateTime64([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 133, line 134) (in query: SELECT YYYYMMDDhhmmssToDateTime64([], [], []);) 2025.06.13 15:48:11.142972 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Array(Nothing): In scope SELECT YYYYMMDDhhmmssToDateTime64([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:11.264099 [ 5110 ] {f242d482-1aca-4e64-9740-4aa26e14d2cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 134, line 135) (in query: SELECT _CAST([], [], []);) 2025.06.13 15:48:11.280298 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:11.428057 [ 5005 ] {fe2eae37-6177-4ec1-9444-eb6911b4f523} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_gl0qamjw.test_constraints (a30f9b93-565e-4070-b962-be6160cbb867) is violated at row 1. Expression: (b > 10). Column values: b = 10. (VIOLATED_CONSTRAINT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51178) (comment: 00953_constraints_operations.sh) (query 1, line 1) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5e9077 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031da1148 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:11.444645 [ 5005 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_gl0qamjw.test_constraints (a30f9b93-565e-4070-b962-be6160cbb867) is violated at row 1. Expression: (b > 10). Column values: b = 10. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5e9077 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031da1148 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:11.482899 [ 5110 ] {1aaaa8c8-42d3-4a44-a341-4bb082fa2278} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 135, line 136) (in query: SELECT __actionName([], [], []);) 2025.06.13 15:48:11.490176 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:11.561532 [ 8101 ] {ee140b3b-5b95-4504-84fa-0d2719a76af3} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 857, line 857) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) != N as r FORMAT CSV;) 2025.06.13 15:48:11.580815 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:11.603631 [ 5110 ] {f8c9a046-8b65-487c-a159-f94532008359} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 136, line 137) (in query: SELECT __bitBoolMaskAnd([], [], []);) 2025.06.13 15:48:11.611238 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:11.693042 [ 5110 ] {f2dbb837-54b0-4e2f-904c-ca70129c8c56} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 137, line 138) (in query: SELECT __bitBoolMaskOr([], [], []);) 2025.06.13 15:48:11.708071 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:11.894772 [ 5110 ] {1f29928c-f4bc-4ffa-83f1-b6cac2801923} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 138, line 139) (in query: SELECT __bitSwapLastTwo([], [], []);) 2025.06.13 15:48:11.899339 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:12.022946 [ 5110 ] {7b15ed94-07dd-432c-9864-f056b7345dbf} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 139, line 140) (in query: SELECT __bitWrapperFunc([], [], []);) 2025.06.13 15:48:12.062561 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:12.072798 [ 3894 ] {b8122c18-0c40-47dd-a8b1-89516a6fdd20} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53056) (comment: 02947_non_post_request_should_be_readonly.sh) (in query: CREATE DATABASE non_post_request_test_test_qd4fufn6 ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4cf56 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x000000002bd4b7e4 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002bd58b36 7. ./build_docker/./src/Access/ContextAccess.cpp:827: bool DB::ContextAccess::checkAccessImpl(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002bd1bb89 8. ./src/Access/ContextAccess.h:261: void DB::Context::checkAccessImpl(DB::AccessRightsElements const&) const @ 0x000000002d4bb5a7 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2337: DB::InterpreterCreateQuery::execute() @ 0x000000002dc89729 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:48:12.077395 [ 3894 ] {b8122c18-0c40-47dd-a8b1-89516a6fdd20} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4cf56 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x000000002bd4b7e4 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002bd58b36 7. ./build_docker/./src/Access/ContextAccess.cpp:827: bool DB::ContextAccess::checkAccessImpl(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002bd1bb89 8. ./src/Access/ContextAccess.h:261: void DB::Context::checkAccessImpl(DB::AccessRightsElements const&) const @ 0x000000002d4bb5a7 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2337: DB::InterpreterCreateQuery::execute() @ 0x000000002dc89729 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:12.197646 [ 5110 ] {338dbcfa-87a5-46ef-bf09-3db474973f16} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 140, line 141) (in query: SELECT __getScalar([], [], []);) 2025.06.13 15:48:12.223392 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:12.267076 [ 2860 ] {847dde72-1e31-4d7c-9ddb-bc97e0492850} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53064) (comment: 02947_non_post_request_should_be_readonly.sh) (in query: CREATE DATABASE non_post_request_test_test_qd4fufn6 ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4cf56 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x000000002bd4b7e4 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002bd58b36 7. ./build_docker/./src/Access/ContextAccess.cpp:827: bool DB::ContextAccess::checkAccessImpl(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002bd1bb89 8. ./src/Access/ContextAccess.h:261: void DB::Context::checkAccessImpl(DB::AccessRightsElements const&) const @ 0x000000002d4bb5a7 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2337: DB::InterpreterCreateQuery::execute() @ 0x000000002dc89729 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:48:12.287295 [ 2860 ] {847dde72-1e31-4d7c-9ddb-bc97e0492850} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002bd4cf56 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x000000002bd4b7e4 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x000000002bd58b36 7. ./build_docker/./src/Access/ContextAccess.cpp:827: bool DB::ContextAccess::checkAccessImpl(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x000000002bd1bb89 8. ./src/Access/ContextAccess.h:261: void DB::Context::checkAccessImpl(DB::AccessRightsElements const&) const @ 0x000000002d4bb5a7 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2337: DB::InterpreterCreateQuery::execute() @ 0x000000002dc89729 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:12.459703 [ 5110 ] {1b48724d-d6aa-42f0-a339-dae07ec38b7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 141, line 142) (in query: SELECT __scalarSubqueryResult([], [], []);) 2025.06.13 15:48:12.533791 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:12.556707 [ 8101 ] {3b8efbe7-aded-4a2e-8f78-6f82f60e2a36} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 862, line 862) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt8(-1) as r FORMAT CSV;) 2025.06.13 15:48:12.564159 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:12.602188 [ 5110 ] {55d8ccc1-8325-4afb-92d6-008d4038ed10} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 142, line 143) (in query: SELECT abs([], [], []);) 2025.06.13 15:48:12.610212 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:12.799065 [ 5110 ] {491fff55-74f9-4521-9c0d-a7dba3e7b2a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 143, line 144) (in query: SELECT accurateCast([], [], []);) 2025.06.13 15:48:12.806707 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:12.925037 [ 5110 ] {405efbcd-964d-4b85-b59b-76f6fcf23598} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Array(Nothing): In scope SELECT accurateCastOrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 144, line 145) (in query: SELECT accurateCastOrDefault([], [], []);) 2025.06.13 15:48:12.940598 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Array(Nothing): In scope SELECT accurateCastOrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:13.039845 [ 5110 ] {fb51af0e-2c8d-456c-ae33-1b6c5e7715d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 145, line 146) (in query: SELECT accurateCastOrNull([], [], []);) 2025.06.13 15:48:13.053238 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:13.172388 [ 5110 ] {dfa752cd-c0be-4619-a654-2d9fb13fc4bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 146, line 147) (in query: SELECT acos([], [], []);) 2025.06.13 15:48:13.237012 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:13.317993 [ 5110 ] {7cb1600e-f0f8-447e-ad43-e4e17bbe4a8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 147, line 148) (in query: SELECT acosh([], [], []);) 2025.06.13 15:48:13.340378 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:13.457456 [ 5110 ] {4f2b36b0-afc8-4fd9-8412-fe511748c9fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 148, line 149) (in query: SELECT addDate([], [], []);) 2025.06.13 15:48:13.468147 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:13.523460 [ 5005 ] {030d219f-7bc8-4da9-a690-2786f21d6309} executeQuery: Code: 57. DB::Exception: Table test_9.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58266) (comment: 02661_read_from_archive_7z.sh) (query 1, line 1) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_9_7z_archive*.7z :: 02661_read_from_archive_test_9_7z_data{2..3}.csv')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:48:13.550286 [ 5005 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:48:13.671358 [ 18511 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:13.673681 [ 18511 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:13.681206 [ 8101 ] {8eb31911-d7e8-40be-8785-365c0f0f5c66} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 867, line 867) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) != N as r FORMAT CSV;) 2025.06.13 15:48:13.696717 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:13.727326 [ 5110 ] {c6253c89-4bd9-4cc9-849d-023522873077} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addDays. Must be a DateTime/DateTime64: In scope SELECT addDays([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 149, line 150) (in query: SELECT addDays([], [], []);) 2025.06.13 15:48:13.744631 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addDays. Must be a DateTime/DateTime64: In scope SELECT addDays([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:13.864975 [ 5110 ] {8eb9ff8a-1456-4742-bb98-c8fb856bf988} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addHours. Must be a DateTime/DateTime64: In scope SELECT addHours([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 150, line 151) (in query: SELECT addHours([], [], []);) 2025.06.13 15:48:13.890757 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addHours. Must be a DateTime/DateTime64: In scope SELECT addHours([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:13.999181 [ 5110 ] {7e98f8d6-2589-4e35-9ae9-4efab47c50d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 151, line 152) (in query: SELECT addInterval([], [], []);) 2025.06.13 15:48:14.007256 [ 8432 ] {} TCPHandler: TCPHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_rlxznkrm` for 3155695200s has been exceeded: failed_sequential_authentications = 2/1. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_rlxznkrm`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::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&&) @ 0x000000002bdae137 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdadf07 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdad381 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdabf12 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdabe9b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbf804 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:14.009601 [ 8432 ] {} ServerErrorHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_rlxznkrm` for 3155695200s has been exceeded: failed_sequential_authentications = 2/1. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_rlxznkrm`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::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&&) @ 0x000000002bdae137 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdadf07 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdad381 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdabf12 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdabe9b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbf804 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:14.036112 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:14.248584 [ 5110 ] {4df1cfea-787e-4cc3-95eb-16c63350ff4c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMicroseconds. Must be a DateTime/DateTime64: In scope SELECT addMicroseconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 152, line 153) (in query: SELECT addMicroseconds([], [], []);) 2025.06.13 15:48:14.263980 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMicroseconds. Must be a DateTime/DateTime64: In scope SELECT addMicroseconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:14.480244 [ 5110 ] {be2dd772-56a8-4e58-9fa4-913cb0335ea5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMilliseconds. Must be a DateTime/DateTime64: In scope SELECT addMilliseconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 153, line 154) (in query: SELECT addMilliseconds([], [], []);) 2025.06.13 15:48:14.506453 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMilliseconds. Must be a DateTime/DateTime64: In scope SELECT addMilliseconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:14.640234 [ 5110 ] {64f2e926-5b38-4168-9ef3-3200937c996a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMinutes. Must be a DateTime/DateTime64: In scope SELECT addMinutes([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 154, line 155) (in query: SELECT addMinutes([], [], []);) 2025.06.13 15:48:14.663570 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMinutes. Must be a DateTime/DateTime64: In scope SELECT addMinutes([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:14.681683 [ 8101 ] {c79c40a3-4f0b-4a47-a47f-c5282b6c90a5} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 872, line 872) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt16(1) as r FORMAT CSV;) 2025.06.13 15:48:14.720494 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:14.794764 [ 5110 ] {389287b7-4b99-4969-977a-488969bf09e2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMonths. Must be a DateTime/DateTime64: In scope SELECT addMonths([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 155, line 156) (in query: SELECT addMonths([], [], []);) 2025.06.13 15:48:14.823279 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMonths. Must be a DateTime/DateTime64: In scope SELECT addMonths([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:14.935540 [ 5110 ] {a63a29fd-83dd-46c9-a960-b2a90424c7a7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addNanoseconds. Must be a DateTime/DateTime64: In scope SELECT addNanoseconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 156, line 157) (in query: SELECT addNanoseconds([], [], []);) 2025.06.13 15:48:14.958540 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addNanoseconds. Must be a DateTime/DateTime64: In scope SELECT addNanoseconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:15.091655 [ 5110 ] {1e305eea-57ce-4ecc-8d61-859bb91389a4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addQuarters. Must be a DateTime/DateTime64: In scope SELECT addQuarters([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 157, line 158) (in query: SELECT addQuarters([], [], []);) 2025.06.13 15:48:15.100849 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addQuarters. Must be a DateTime/DateTime64: In scope SELECT addQuarters([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:15.178167 [ 2860 ] {1bf09f14-be90-42d0-a48e-6120273d6e49} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_i0frc2hu.table_for_rename_pk (dea16984-4aa0-486d-9e01-a267b94adf66)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58292) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (query 3, line 18) (in query: INSERT INTO table_for_rename_pk SELECT toDate('2019-10-01') + number % 3, number, number, number, toString(number), toString(number) from numbers(9);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:48:15.178848 [ 18510 ] {722a5d13-0a17-4a7d-be50-f5ba5cbe8d69} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58374) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: CREATE TABLE single_col_partition_key (`x` UInt32) ENGINE = MergeTree PARTITION BY intDiv(x, 10) ORDER BY x SETTINGS index_granularity = 4, min_bytes_for_wide_part = 139585471, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 237281077, compact_parts_max_granules_to_buffer = 232, compact_parts_merge_max_bytes_to_prefetch_part = 14544347, merge_max_block_size = 22323, old_parts_lifetime = 399., 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 = 4948964216, index_granularity_bytes = 5334448, 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 = true, marks_compress_block_size = 55079, primary_key_compress_block_size = 75097, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:15.200716 [ 18510 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:15.212347 [ 2860 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_i0frc2hu.table_for_rename_pk (dea16984-4aa0-486d-9e01-a267b94adf66)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:48:15.324691 [ 5110 ] {1823eff7-119c-4685-bfd4-76d85bc21b96} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addSeconds. Must be a DateTime/DateTime64: In scope SELECT addSeconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 158, line 159) (in query: SELECT addSeconds([], [], []);) 2025.06.13 15:48:15.373910 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addSeconds. Must be a DateTime/DateTime64: In scope SELECT addSeconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:15.486164 [ 8442 ] {b6bcd813-f6c9-4501-af26-0dae416fd907} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58406) (comment: 02918_join_pm_lc_crash.sql) (query 2, line 4) (in query: SET enable_analyzer = 0, join_use_nulls = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:15.500516 [ 8442 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:15.525636 [ 5110 ] {807420c0-c6a0-481a-b0ce-b794b55dbb58} executeQuery: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 159, line 160) (in query: SELECT addTupleOfIntervals([], [], []);) 2025.06.13 15:48:15.530216 [ 18510 ] {43d03287-a7cf-4083-b552-6d65e1c6878e} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_i0frc2hu.table_for_rename_pk (dea16984-4aa0-486d-9e01-a267b94adf66)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44358) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: DROP DATABASE IF EXISTS test_i0frc2hu SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:15.541924 [ 18510 ] {43d03287-a7cf-4083-b552-6d65e1c6878e} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_i0frc2hu.table_for_rename_pk (dea16984-4aa0-486d-9e01-a267b94adf66)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:15.546508 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:15.637662 [ 2860 ] {a812da96-62d6-4776-b13e-23725c33fdb4} 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.20286.altinityantalya (altinity build)) (from [::1]:58414) (comment: 03008_s3_plain_rewritable_alter_partition.sh) (query 1, line 1) (in query: ALTER TABLE 03008_alter_partition ATTACH PARTITION 2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871846f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5380: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000030cfba5b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4185f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:48:15.647507 [ 5110 ] {96031253-9fc7-4773-b09e-d0f361a0999f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addWeeks. Must be a DateTime/DateTime64: In scope SELECT addWeeks([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 160, line 161) (in query: SELECT addWeeks([], [], []);) 2025.06.13 15:48:15.660695 [ 2860 ] {} TCPHandler: Code: 344. DB::Exception: Partition operation ALTER TABLE ATTACH PARTITION is not supported for immutable disk '03008_alter_partition'. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871846f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5380: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000030cfba5b 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4185f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:48:15.703217 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addWeeks. Must be a DateTime/DateTime64: In scope SELECT addWeeks([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:15.768000 [ 8101 ] {22e4b70b-3306-4895-835d-a33c0460c98d} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 877, line 877) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) != N as r FORMAT CSV;) 2025.06.13 15:48:15.836618 [ 8432 ] {73e2ba02-e52f-4219-8112-c8aa52b07c74} executeQuery: Code: 60. DB::Exception: Table test_11.single_col_partition_key does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58422) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: INSERT INTO single_col_partition_key VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:15.861863 [ 8432 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.single_col_partition_key does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:15.894960 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:15.904311 [ 5110 ] {f8ef4fa3-fd53-413f-8d24-44b45e48338d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addYears. Must be a DateTime/DateTime64: In scope SELECT addYears([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 161, line 162) (in query: SELECT addYears([], [], []);) 2025.06.13 15:48:15.916667 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addYears. Must be a DateTime/DateTime64: In scope SELECT addYears([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:16.255672 [ 3838 ] {655424b0-5a7e-49e4-a9dd-3077aeb79b65} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:51630) (comment: 03164_parallel_replicas_range_filter_min_max.sql) (query 16, line 137) (in query: SELECT `__table1`.`k` AS `k` FROM `test_6twq1p5v`.`range_filter_custom_range_test_2` AS `__table1` WHERE (`k` >= 3) AND (`k` < 5)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:48:16.261362 [ 5110 ] {3f88b019-a09c-4365-86cf-b4fcfab73a08} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 162, line 163) (in query: SELECT addressToLine([], [], []);) 2025.06.13 15:48:16.267119 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:16.267193 [ 3838 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:48:16.426717 [ 5110 ] {4168938f-7c7b-4e4e-834c-b7963381d9d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 163, line 164) (in query: SELECT addressToLineWithInlines([], [], []);) 2025.06.13 15:48:16.447722 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:16.509940 [ 8442 ] {51c745ef-ca6e-4dc4-bea8-688e00f04eef} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'single_col_partition_key' in scope SELECT count() FROM single_col_partition_key WHERE x < 3. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58468) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: SELECT count() FROM single_col_partition_key WHERE x < 3 FORMAT XML SETTINGS optimize_trivial_count_query = 0, optimize_use_implicit_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:16.540355 [ 8442 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'single_col_partition_key' in scope SELECT count() FROM single_col_partition_key WHERE x < 3. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:16.599128 [ 5110 ] {f2147719-64da-49eb-aacd-113c3984eb92} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 164, line 165) (in query: SELECT addressToSymbol([], [], []);) 2025.06.13 15:48:16.612227 [ 9642 ] {13da9c4a-5b96-4af0-a9a4-665cf9de43f8} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50906) (comment: 03164_parallel_replicas_range_filter_min_max.sql) (query 16, line 137) (in query: SELECT count() FROM ( SELECT * FROM cluster(parallel_replicas, currentDatabase(), range_filter_custom_range_test_2) SETTINGS prefer_localhost_replica = 0, max_parallel_replicas = 12, distributed_group_by_no_merge = 0, enable_parallel_replicas = 1, parallel_replicas_custom_key = 'k', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key_range_lower = 0, parallel_replicas_custom_key_range_upper = 13 );), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:48:16.618735 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:16.653033 [ 7755 ] {} void DB::TCPHandler::runImpl(): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:59190). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:422: DB::TCPHandler::runImpl() @ 0x00000000316a9ed9 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:16.665953 [ 7755 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59190, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000023b5b455 8. ./build_docker/./src/Server/TCPHandler.cpp:1804: DB::TCPHandler::receiveAddendum() @ 0x00000000316b523e 9. ./build_docker/./src/Server/TCPHandler.cpp:350: DB::TCPHandler::runImpl() @ 0x00000000316a1a32 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:16.666940 [ 4166 ] {4bafdec3-4987-4416-b64e-fd40da2e99af} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:37338). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:37338) (comment: 03164_parallel_replicas_range_filter_min_max.sql) (query 16, line 137) (in query: SELECT `__table1`.`k` AS `k` FROM `test_6twq1p5v`.`range_filter_custom_range_test_2` AS `__table1` WHERE `k` >= 12), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b951d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:48:16.682094 [ 7755 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59190, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000023b5b455 8. ./build_docker/./src/Server/TCPHandler.cpp:1804: DB::TCPHandler::receiveAddendum() @ 0x00000000316b523e 9. ./build_docker/./src/Server/TCPHandler.cpp:350: DB::TCPHandler::runImpl() @ 0x00000000316a1a32 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:16.696424 [ 4166 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:37338). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b951d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:48:16.698469 [ 2860 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:47514, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:16.699205 [ 2860 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:47514, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:16.715686 [ 9642 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:48:16.728919 [ 5110 ] {5a6c474f-07c1-48b2-83ca-850c29c56172} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_decrypt_mysql'. Expected: decryption mode string, got: Array(Nothing): In scope SELECT aes_decrypt_mysql([], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 165, line 166) (in query: SELECT aes_decrypt_mysql([], '[HIDDEN]')) 2025.06.13 15:48:16.762744 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_decrypt_mysql'. Expected: decryption mode string, got: Array(Nothing): In scope SELECT aes_decrypt_mysql([], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:16.826367 [ 8101 ] {6d9fc384-3e2a-4280-b64b-18a9f3acacf6} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 882, line 882) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt16(-1) as r FORMAT CSV;) 2025.06.13 15:48:16.897235 [ 5110 ] {9eec3481-02c9-48dc-aacb-3d38993e343d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_encrypt_mysql'. Expected: encryption mode string, got: Array(Nothing): In scope SELECT aes_encrypt_mysql([], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 166, line 167) (in query: SELECT aes_encrypt_mysql([], '[HIDDEN]')) 2025.06.13 15:48:16.908218 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_encrypt_mysql'. Expected: encryption mode string, got: Array(Nothing): In scope SELECT aes_encrypt_mysql([], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:16.915040 [ 4107 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:16.918508 [ 4107 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:16.976122 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:17.044758 [ 5110 ] {3f670119-64e2-4111-84e0-8b225a15cd19} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'age'. Expected: String, got: Array(Nothing): In scope SELECT age([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 167, line 168) (in query: SELECT age([], [], []);) 2025.06.13 15:48:17.055490 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'age'. Expected: String, got: Array(Nothing): In scope SELECT age([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:17.065513 [ 34312 ] {47506fad-324c-4a7b-b736-25d653c5d814} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'single_col_partition_key' in scope SELECT count() FROM single_col_partition_key WHERE x >= 11. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58522) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: SELECT count() FROM single_col_partition_key WHERE x >= 11 FORMAT XML SETTINGS optimize_trivial_count_query = 0, optimize_use_implicit_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:17.095304 [ 34312 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'single_col_partition_key' in scope SELECT count() FROM single_col_partition_key WHERE x >= 11. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:17.306034 [ 4107 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:17.312662 [ 4107 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:17.313562 [ 5110 ] {43adf7af-91ae-40be-8435-cf04ec1df7e5} executeQuery: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 168, line 169) (in query: SELECT aggThrow([], [], []);) 2025.06.13 15:48:17.321395 [ 5110 ] {} TCPHandler: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) 2025.06.13 15:48:17.646390 [ 3821 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:17.648262 [ 3821 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:17.656069 [ 5110 ] {40f382cd-c9bb-4e9e-a438-ad1f587c53f2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT alphaTokens([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 169, line 170) (in query: SELECT alphaTokens([], [], []);) 2025.06.13 15:48:17.659420 [ 34313 ] {c5e00977-cff0-49c8-99d9-43ff2838b43d} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_13.test (f1d94226-b7c6-4b8a-9b4b-a6f9932eed46), because some tables depend on it: test_13.test_dict. (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58572) (comment: 01719_join_timezone.sql) (query 1, line 1) (in query: DROP TABLE IF EXISTS test;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d60a06f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd0c4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd596 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca75b3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:48:17.690853 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT alphaTokens([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:17.691690 [ 34313 ] {} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_13.test (f1d94226-b7c6-4b8a-9b4b-a6f9932eed46), because some tables depend on it: test_13.test_dict. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d60a06f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd0c4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd596 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca75b3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:48:17.773472 [ 4107 ] {360b09b2-679f-4027-a969-8ff5e4aa51e3} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'single_col_partition_key' in scope SELECT count() FROM single_col_partition_key WHERE x = 20. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58588) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: SELECT count() FROM single_col_partition_key WHERE x = 20 FORMAT XML SETTINGS optimize_trivial_count_query = 0, optimize_use_implicit_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:17.805105 [ 4107 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'single_col_partition_key' in scope SELECT count() FROM single_col_partition_key WHERE x = 20. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:17.805317 [ 5110 ] {32d7e5b6-ee7a-414c-a9fb-60feaebb4777} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 170, line 171) (in query: SELECT analysisOfVariance([], [], []);) 2025.06.13 15:48:17.855199 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:17.945337 [ 5110 ] {21ae4568-c7e7-44d3-81c5-4d84495e390a} executeQuery: Code: 43. DB::Exception: Illegal type (Array(Nothing)) of 1 argument of function and: In scope SELECT [] AND [] AND []. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 171, line 172) (in query: SELECT and([], [], []);) 2025.06.13 15:48:17.954290 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(Nothing)) of 1 argument of function and: In scope SELECT [] AND [] AND []. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:17.958618 [ 34312 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:17.960427 [ 34312 ] {} ServerErrorHandler: Code: 516. DB::Exception: 2884_user_test_rlxznkrm: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./build_docker/./src/Access/AccessControl.cpp:643: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbff09 5. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 6. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 7. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 8. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:18.008967 [ 8101 ] {5b20469e-b9b2-4f9a-b8c4-4301a886c279} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 887, line 887) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) != N as r FORMAT CSV;) 2025.06.13 15:48:18.024926 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:18.030747 [ 5110 ] {0d439097-3708-439f-9a5d-36c733d99e62} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 172, line 173) (in query: SELECT anova([], [], []);) 2025.06.13 15:48:18.036080 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:18.172145 [ 5110 ] {48381531-47db-484a-84fd-b7cad46cd2eb} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 173, line 174) (in query: SELECT any([], [], []);) 2025.06.13 15:48:18.207406 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:18.252172 [ 34302 ] {} TCPHandler: TCPHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_rlxznkrm` for 3155695200s has been exceeded: failed_sequential_authentications = 5/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_rlxznkrm`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::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&&) @ 0x000000002bdae137 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdadf07 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdad381 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdabf12 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdabe9b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbf804 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:18.257009 [ 34302 ] {} ServerErrorHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_rlxznkrm` for 3155695200s has been exceeded: failed_sequential_authentications = 5/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_rlxznkrm`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::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&&) @ 0x000000002bdae137 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdadf07 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdad381 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdabf12 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdabe9b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbf804 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:18.390194 [ 5110 ] {596a32bb-49e8-424e-819b-84a3d4e1ddaf} executeQuery: Code: 42. DB::Exception: Aggregate function anyHeavy requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 174, line 175) (in query: SELECT anyHeavy([], [], []);) 2025.06.13 15:48:18.395945 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyHeavy requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:18.450076 [ 4107 ] {6a09f169-27ab-40f5-af44-7d1a1e22b900} executeQuery: Code: 60. DB::Exception: Table test_11.single_col_partition_key does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58628) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: DROP TABLE single_col_partition_key), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:18.489196 [ 4107 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.single_col_partition_key does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:18.490566 [ 5110 ] {e1361e31-b247-49fe-84ab-534aa18da8b2} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 175, line 176) (in query: SELECT anyLast([], [], []);) 2025.06.13 15:48:18.517151 [ 34312 ] {} TCPHandler: TCPHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_rlxznkrm` for 3155695200s has been exceeded: failed_sequential_authentications = 6/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_rlxznkrm`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::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&&) @ 0x000000002bdae137 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdadf07 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdad381 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdabf12 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdabe9b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbf804 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:18.517962 [ 34312 ] {} ServerErrorHandler: Code: 201. DB::Exception: Quota for user `2884_user_test_rlxznkrm` for 3155695200s has been exceeded: failed_sequential_authentications = 6/4. Interval will end at 2069-12-31 07:00:00. Name of quota template: `2884_quota_test_rlxznkrm`. (QUOTA_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::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&&) @ 0x000000002bdae137 5. ./build_docker/./src/Access/EnabledQuota.cpp:32: DB::EnabledQuota::Impl::throwQuotaExceed(String const&, String const&, DB::QuotaType, unsigned long, unsigned long, std::chrono::duration>, std::chrono::time_point>>) @ 0x000000002bdadf07 6. ./build_docker/./src/Access/EnabledQuota.cpp:64: DB::EnabledQuota::Impl::used(String const&, DB::EnabledQuota::Intervals const&, DB::QuotaType, unsigned long, std::chrono::time_point>>, bool) @ 0x000000002bdad381 7. ./build_docker/./src/Access/EnabledQuota.cpp:252: DB::EnabledQuota::used(std::pair const&, bool) const @ 0x000000002bdabf12 8. ./build_docker/./src/Access/EnabledQuota.cpp:244: DB::EnabledQuota::used(DB::QuotaType, unsigned long, bool) const @ 0x000000002bdabe9b 9. ./build_docker/./src/Access/AccessControl.cpp:599: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002bcbf804 10. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df289e0 11. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000002df28255 12. ./build_docker/./src/Server/TCPHandler.cpp:1797: DB::TCPHandler::receiveHello() @ 0x00000000316b15db 13. ./build_docker/./src/Server/TCPHandler.cpp:338: DB::TCPHandler::runImpl() @ 0x00000000316a187e 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:18.531725 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:18.648958 [ 5110 ] {e60f80cd-7684-4ecd-9f1f-1668f4100cec} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 176, line 177) (in query: SELECT anyLastRespectNulls([], [], []);) 2025.06.13 15:48:18.669838 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:18.825787 [ 5110 ] {5d9c3157-2b28-415c-bb08-468d42f4a6f8} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 177, line 178) (in query: SELECT anyLast_respect_nulls([], [], []);) 2025.06.13 15:48:18.831559 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:18.944099 [ 5110 ] {3fa26db9-89c5-43e2-ac08-f86b33a47c1e} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 178, line 179) (in query: SELECT anyRespectNulls([], [], []);) 2025.06.13 15:48:18.975913 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:19.058591 [ 8101 ] {f88e4510-a9b8-47b1-a440-d4db4d4f903c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 892, line 892) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt32(1) as r FORMAT CSV;) 2025.06.13 15:48:19.068918 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:19.098020 [ 5110 ] {10cdc064-c7a1-4cdb-b58b-6621a83c2e22} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 179, line 180) (in query: SELECT anyValueRespectNulls([], [], []);) 2025.06.13 15:48:19.111224 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:19.242096 [ 5110 ] {8eccb01e-6da5-4d59-b465-6159004ee74d} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 180, line 181) (in query: SELECT any_respect_nulls([], [], []);) 2025.06.13 15:48:19.256285 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:19.409126 [ 5110 ] {19ea3433-9c14-4294-a4a0-da99fe04bfa3} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 181, line 182) (in query: SELECT any_value([], [], []);) 2025.06.13 15:48:19.419888 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:19.544777 [ 5110 ] {8e646dbc-1f7a-4ed2-907f-2238aa5fccd3} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 182, line 183) (in query: SELECT any_value_respect_nulls([], [], []);) 2025.06.13 15:48:19.554447 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:19.687879 [ 5110 ] {97b4088b-349d-4f93-81e6-d75bb605070e} executeQuery: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 183, line 184) (in query: SELECT appendTrailingCharIfAbsent([], [], []);) 2025.06.13 15:48:19.774832 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:19.845598 [ 5110 ] {d8523fe3-a596-4727-93cf-75d31a58b78d} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 184, line 185) (in query: SELECT approx_top_count([], [], []);) 2025.06.13 15:48:19.873644 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:19.965967 [ 5110 ] {f769c303-e917-4261-8bd7-409003305505} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 185, line 186) (in query: SELECT approx_top_k([], [], []);) 2025.06.13 15:48:19.973288 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:20.022706 [ 5110 ] {cda81072-ab87-4a19-a6a1-0fedd428eb57} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 186, line 187) (in query: SELECT approx_top_sum([], [], []);) 2025.06.13 15:48:20.032756 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:20.123670 [ 34301 ] {435f5dda-7665-4d40-a85c-97325870ee6b} executeQuery: Code: 43. DB::Exception: First argument for function tupleNames must be a tuple: In scope SELECT tupleNames(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58456) (comment: 02890_named_tuple_functions.sql) (query 14, line 20) (in query: select tupleNames(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::TupleNamesOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0d45d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:48:20.127858 [ 5110 ] {ea9cadd6-577b-4bf1-971e-fd3b3bd4c865} executeQuery: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 187, line 188) (in query: SELECT argMax([], [], []);) 2025.06.13 15:48:20.146385 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:20.147851 [ 8101 ] {f8e76e3d-a799-4ff3-8673-0923958f0ef3} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 897, line 897) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) != N as r FORMAT CSV;) 2025.06.13 15:48:20.149111 [ 34301 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleNames must be a tuple: In scope SELECT tupleNames(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::TupleNamesOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000020d0d45d 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:48:20.152989 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:20.212610 [ 5110 ] {7e27caa5-821e-451d-93e7-9d08230c2e21} executeQuery: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 188, line 189) (in query: SELECT argMin([], [], []);) 2025.06.13 15:48:20.229070 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:20.288706 [ 3821 ] {d6621fb0-ede1-4bae-905a-9bd1c00fc26c} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58756) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: CREATE TABLE composite_partition_key (`a` UInt32, `b` UInt32, `c` UInt32) ENGINE = MergeTree PARTITION BY (intDiv(a, 100), intDiv(b, 10), c) ORDER BY c SETTINGS index_granularity = 5074, min_bytes_for_wide_part = 139585471, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 237281077, compact_parts_max_granules_to_buffer = 232, compact_parts_merge_max_bytes_to_prefetch_part = 14544347, merge_max_block_size = 22323, old_parts_lifetime = 399., 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 = 4948964216, index_granularity_bytes = 5334448, 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 = true, marks_compress_block_size = 55079, primary_key_compress_block_size = 75097, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:20.299194 [ 3821 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:20.566026 [ 5110 ] {fb2040be-6781-42ed-98e8-a02f2722040c} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayAUC([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 190, line 191) (in query: SELECT arrayAUC([], [], []);) 2025.06.13 15:48:20.594585 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayAUC([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:20.667515 [ 3895 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:20.716346 [ 5110 ] {033785e0-0ded-4099-bddc-b2bb35f61c7a} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nothing, should be a number: In scope SELECT arrayAUCPR([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 191, line 192) (in query: SELECT arrayAUCPR([], [], []);) 2025.06.13 15:48:20.734274 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nothing, should be a number: In scope SELECT arrayAUCPR([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:20.848431 [ 4107 ] {5cbf99a0-3e13-437c-902b-ad6973bf8496} executeQuery: Code: 60. DB::Exception: Table test_11.composite_partition_key does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58818) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: INSERT INTO composite_partition_key VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:20.878889 [ 4107 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.composite_partition_key does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:20.950714 [ 5110 ] {2243e311-f2b6-43b5-81ae-230b03faa015} executeQuery: Code: 43. DB::Exception: First argument for function arrayAll must be a function. Actual Array(Nothing): In scope SELECT arrayAll([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 192, line 193) (in query: SELECT arrayAll([], [], []);) 2025.06.13 15:48:20.987543 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayAll must be a function. Actual Array(Nothing): In scope SELECT arrayAll([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:21.173847 [ 5110 ] {70489e29-8b5d-4efb-adbc-62c1ad144ad3} executeQuery: Code: 43. DB::Exception: First argument for function arrayAvg must be a function. Actual Array(Nothing): In scope SELECT arrayAvg([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 193, line 194) (in query: SELECT arrayAvg([], [], []);) 2025.06.13 15:48:21.210774 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayAvg must be a function. Actual Array(Nothing): In scope SELECT arrayAvg([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:21.268725 [ 8101 ] {4eee5d74-76bd-4aaa-bf05-7c9524fd9d67} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 902, line 902) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt32(-1) as r FORMAT CSV;) 2025.06.13 15:48:21.329696 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:21.423125 [ 5110 ] {780305e0-dd88-45f2-b58c-9a7da2efb755} executeQuery: Code: 43. DB::Exception: First argument for function arrayCompact must be a function. Actual Array(Nothing): In scope SELECT arrayCompact([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 194, line 195) (in query: SELECT arrayCompact([], [], []);) 2025.06.13 15:48:21.434764 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCompact must be a function. Actual Array(Nothing): In scope SELECT arrayCompact([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:21.540675 [ 3821 ] {abce78c1-bdbb-43a4-8276-f097a135fbe8} 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.20286.altinityantalya (altinity build)) (from [::1]:58820) (comment: 03261_pr_semi_anti_join.sql) (query 3, line 4) (in query: CREATE TABLE t1 (`x` UInt32, `s` String) ENGINE = ReplicatedMergeTree('/clickhouse/{database}/t1', '1') ORDER BY tuple() SETTINGS index_granularity = 19683, min_bytes_for_wide_part = 536454481, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 33, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 525913535, compact_parts_max_granules_to_buffer = 139, compact_parts_merge_max_bytes_to_prefetch_part = 754770, merge_max_block_size = 19978, old_parts_lifetime = 255., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 533474, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 24118477, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 76, 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 = 15768, primary_key_compress_block_size = 23807, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:21.565607 [ 6193 ] {68d5c558-2122-4b5b-b34b-99be07546148} executeQuery: Code: 60. DB::Exception: Table test_11.composite_partition_key does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58862) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: INSERT INTO composite_partition_key VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:21.605852 [ 3821 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002c76fc84 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1081: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002c772e67 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c773ffd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:21.606435 [ 6193 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.composite_partition_key does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:21.787544 [ 5110 ] {6b9e90e1-36e1-4799-b824-145d50028061} executeQuery: Code: 43. DB::Exception: First argument for function arrayCount must be a function. Actual Array(Nothing): In scope SELECT arrayCount([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 196, line 197) (in query: SELECT arrayCount([], [], []);) 2025.06.13 15:48:21.811121 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCount must be a function. Actual Array(Nothing): In scope SELECT arrayCount([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:22.023398 [ 5110 ] {dde8dba4-9bca-459c-adac-9e81863bb2b3} executeQuery: Code: 43. DB::Exception: First argument for function arrayCumSum must be a function. Actual Array(Nothing): In scope SELECT arrayCumSum([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 197, line 198) (in query: SELECT arrayCumSum([], [], []);) 2025.06.13 15:48:22.076213 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCumSum must be a function. Actual Array(Nothing): In scope SELECT arrayCumSum([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:22.193478 [ 4107 ] {bb95795e-05a1-4135-83d4-9ef9f42eb291} executeQuery: Code: 60. DB::Exception: Table test_11.composite_partition_key does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58892) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: INSERT INTO composite_partition_key VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:22.222614 [ 4107 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.composite_partition_key does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:22.227989 [ 5110 ] {97c40bbb-537a-49d0-ba10-6c382bf747e3} executeQuery: Code: 43. DB::Exception: First argument for function arrayCumSumNonNegative must be a function. Actual Array(Nothing): In scope SELECT arrayCumSumNonNegative([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 198, line 199) (in query: SELECT arrayCumSumNonNegative([], [], []);) 2025.06.13 15:48:22.241776 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCumSumNonNegative must be a function. Actual Array(Nothing): In scope SELECT arrayCumSumNonNegative([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:22.364372 [ 5110 ] {f8aff428-005d-4650-8f71-1091f652fd97} executeQuery: Code: 43. DB::Exception: First argument for function arrayDifference must be a function. Actual Array(Nothing): In scope SELECT arrayDifference([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 199, line 200) (in query: SELECT arrayDifference([], [], []);) 2025.06.13 15:48:22.370339 [ 8101 ] {8110a599-b377-4c2f-8a51-f4c2dca6778f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 907, line 907) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) != N as r FORMAT CSV;) 2025.06.13 15:48:22.379817 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:22.382512 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayDifference must be a function. Actual Array(Nothing): In scope SELECT arrayDifference([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:22.495595 [ 5110 ] {cb331c73-ecb1-4143-bf39-f6f6b2967289} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 200, line 201) (in query: SELECT arrayDistinct([], [], []);) 2025.06.13 15:48:22.523387 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:22.642472 [ 5110 ] {dba92903-3a9d-4b4e-b37c-427d5bee1341} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 201, line 202) (in query: SELECT arrayDotProduct([], [], []);) 2025.06.13 15:48:22.649039 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:22.808983 [ 5110 ] {1835bfa7-d87c-4510-9276-cdf964cbef17} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 202, line 203) (in query: SELECT arrayElement([], [], []);) 2025.06.13 15:48:22.822735 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:22.858815 [ 3895 ] {cf81206f-5733-402b-ae2a-e44df5513aae} executeQuery: Code: 60. DB::Exception: Table test_11.composite_partition_key does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58922) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: INSERT INTO composite_partition_key VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:22.882223 [ 3895 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.composite_partition_key does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:22.977693 [ 5110 ] {aa6414f8-4efc-409e-b0cc-0b2eab36aa36} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 3, should be 2: In scope SELECT arrayElementOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 203, line 204) (in query: SELECT arrayElementOrNull([], [], []);) 2025.06.13 15:48:23.015589 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 3, should be 2: In scope SELECT arrayElementOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:23.233285 [ 5110 ] {8d02043e-f9b4-484c-bb54-6ac54d844440} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 204, line 205) (in query: SELECT arrayEnumerate([], [], []);) 2025.06.13 15:48:23.246192 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:23.424728 [ 8101 ] {40f54126-f075-424d-a427-fb191b2b3b6e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 912, line 912) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt64(1) as r FORMAT CSV;) 2025.06.13 15:48:23.438434 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:23.504612 [ 34370 ] {51c93955-0262-45fe-8c63-ba5d76369d23} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE a > 400. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58034) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: SELECT count() FROM composite_partition_key WHERE a > 400 FORMAT XML SETTINGS optimize_trivial_count_query = 0, optimize_use_implicit_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:23.522800 [ 34370 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE a > 400. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:24.001181 [ 4172 ] {488cd7e7-4bd3-4757-b230-c371dfdfd1dd} executeQuery: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: SilverlightVersion2: (at row 1) : While executing BSONEachRowRowInputFormat. (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58046) (comment: 02685_bson2.sql) (query 1, line 1) (in query: -- It correctly throws exception about incorrect data: SELECT * FROM format('BSONEachRow', 'WatchID Int64, JavaEnable Int16, Title String, GoodEvent Int16, EventTime DateTime, EventDate Date, CounterID Int32, ClientIP Int32, RegionID Int32, UserID Int64, CounterClass Int16, OS Int16, UserAgent Int16, URL String, Referer String, IsRefresh Int16, RefererCategoryID Int16, RefererRegionID Int32, URLCategoryID Int16, URLRegionID Int32, ResolutionWidth Int16, ResolutionHeight Int16, ResolutionDepth Int16, FlashMajor Int16, FlashMinor Int16, FlashMinor2 String, NetMajor Int16, NetMinor Int16, UserAgentMajor Int16, UserAgentMinor String, CookieEnable Int16, JavascriptEnable Int16, IsMobile Int16, MobilePhone Int16, MobilePhoneModel String, Params String, IPNetworkID Int32, TraficSourceID Int16, SearchEngineID Int16, SearchPhrase String, AdvEngineID Int16, IsArtifical Int16, WindowClientWidth Int16, WindowClientHeight Int16, ClientTimeZone Int16, ClientEventTime DateTime, SilverlightVersion1 Int16, SilverlightVersion2 Int16, SilverlightVersion3 Int32, SilverlightVersion4 Int16, PageCharset String, CodeVersion Int32, IsLink Int16, IsDownload Int16, IsNotBounce Int16, FUniqID Int64, OriginalURL String, HID Int32, IsOldCounter Int16, IsEvent Int16, IsParameter Int16, DontCountHits Int16, WithHash Int16, HitColor String, LocalEventTime DateTime, Age Int16, Sex Int16, Income Int16, Interests Int16, Robotness Int16, RemoteIP Int32, WindowName Int32, OpenerName Int32, HistoryLength Int16, BrowserLanguage String, BrowserCountry String, SocialNetwork String, SocialAction String, HTTPError Int16, SendTiming Int32, DNSTiming Int32, ConnectTiming Int32, ResponseStartTiming Int32, ResponseEndTiming Int32, FetchTiming Int32, SocialSourceNetworkID Int16, SocialSourcePage String, ParamPrice Int64, ParamOrderID String, ParamCurrency String, ParamCurrencyID Int16, OpenstatServiceName String, OpenstatCampaignID String, OpenstatAdID String, OpenstatSourceID String, UTMSource String, UTMMedium String, UTMCampaign String, UTMContent String, UTMTerm String, FromTag String, HasGCLID Int16, RefererHash Int64, URLHash Int64, CLID Int32', $$^WatchIDc*5/ !p~JavaEnableTitleGoodEventEventTime7ðâQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion2SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime&·ãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchID úFÚÓ“2qJavaEnableTitleGoodEventEventTimen$äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeǘãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchIDl!è–|¨@HJavaEnableTitleGoodEventEventTimeÃ)äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime}žãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchID²Ç=ÐŒWJavaEnableTitleGoodEventEventTime8*äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeÝžãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID‹WatchIDéòˆE&LyJavaEnableTitleGoodEventEventTimeJîâQEventDate>CounterIDClientIPº‹I`RegionID'UserIDq—íJd8CounterClassOSUserAgentURL-http://holodilnik.ru/russia/05jul2013&model=0RefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryID¬9URLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajor UserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkIDŒd9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqID%œlû©+kOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime'¡ãQAgeSexIncomeInterests¦:RobotnessRemoteIP9ê3NWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashŽ oâïòeCLID¦WatchID¹ãk=÷±pJavaEnableTitleGoodEventEventTimeÉ ãQEventDate>CounterIDClientIP®Æz·RegionIDGUserID ÎKs}¡ïCounterClassOSUserAgentURLHhttp://afisha.mail.ru/catalog/314/women.ru/ency=1&page3/?errovat-pinnikiRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryID0=URLRegionIDØResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqID:¤ìWëÂmOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeA¶ãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashý€ à#â\CLIDœWatchIDæ1þž oíCJavaEnableTitleGoodEventEventTimeµ0äQEventDate>CounterIDClientIPÉ^{]RegionIDÅUserID&n%Št"6CounterClassOS'UserAgentURL>http://bonprix.ru/index.ru/cinema/art/0 986 424 233 ÑезонRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionID±ResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID‰#(TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime¼£ãQAgeSexIncomeInterestsRobotnessRemoteIP…UWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashX-h³ýX CLID˜WatchID»-ÞC_JavaEnableTitleGoodEventEventTime83äQEventDate>CounterIDClientIPÉ^{]RegionIDÅUserID&n%Št"6CounterClassOS'UserAgentURL:http://bonprix.ru/index.ru/cinema/art/A00387,3797); ru)&bLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionID±ResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID‰#(TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime ¦ãQAgeSexIncomeInterestsRobotnessRemoteIP…UWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashvÀvÍÀ‰ÇCLIDWatchIDìÒŒ\JavaEnableTitleGoodEventEventTime× äQEventDate>CounterIDClientIPgURegionIDåUserIDƒs—yyçófCounterClassOS,UserAgentURL1http://tours/Ekategoriya%2F&sr=http://slovareniyeRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDØesRolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajor UserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¶œTraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeY’ãQAgeSexIncomeInterestsRobotnessRemoteIP€=kWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashh˜´9›DCLID^WatchIDÛ/E‚ÜJÛ{JavaEnableTitleGoodEventEventTimeÖ1ãQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime‹ÏãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID$$);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x0000000017e3cd4f 5. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:806: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003192b278 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 17. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:48:24.016227 [ 4172 ] {} TCPHandler: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: SilverlightVersion2: (at row 1) : While executing BSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x0000000017e3cd4f 5. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:806: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003192b278 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000031906843 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003183f384 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002852f4ab 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 17. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:48:24.045403 [ 34370 ] {ee223c6d-7fa2-40e3-8cfd-01a54b4ed93a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE b = 11. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58056) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: SELECT count() FROM composite_partition_key WHERE b = 11 FORMAT XML SETTINGS optimize_trivial_count_query = 0, optimize_use_implicit_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:24.084901 [ 34370 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE b = 11. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:24.154578 [ 5110 ] {33cc1ef7-f596-42ce-81c9-abb945ee3466} executeQuery: Code: 43. DB::Exception: First argument for function arrayExists must be a function. Actual Array(Nothing): In scope SELECT arrayExists([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 209, line 210) (in query: SELECT arrayExists([], [], []);) 2025.06.13 15:48:24.177695 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayExists must be a function. Actual Array(Nothing): In scope SELECT arrayExists([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:24.337930 [ 5110 ] {b1df96f3-a7d1-45a2-8488-20d782d98e2b} executeQuery: Code: 43. DB::Exception: First argument for function arrayFill must be a function. Actual Array(Nothing): In scope SELECT arrayFill([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 210, line 211) (in query: SELECT arrayFill([], [], []);) 2025.06.13 15:48:24.345864 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFill must be a function. Actual Array(Nothing): In scope SELECT arrayFill([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:24.380670 [ 8101 ] {e2c0ff54-2c7c-4951-8f14-e5f7e081ca7c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 917, line 917) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) != N as r FORMAT CSV;) 2025.06.13 15:48:24.402511 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:24.505926 [ 5110 ] {742d78cb-39b1-4d90-aa58-bd3433ba6fda} executeQuery: Code: 43. DB::Exception: First argument for function arrayFilter must be a function. Actual Array(Nothing): In scope SELECT arrayFilter([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 211, line 212) (in query: SELECT arrayFilter([], [], []);) 2025.06.13 15:48:24.532301 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFilter must be a function. Actual Array(Nothing): In scope SELECT arrayFilter([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:24.653894 [ 4172 ] {3203adad-15a1-46f4-84ea-c7de4f755e9e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE c = 4. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58066) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: SELECT count() FROM composite_partition_key WHERE c = 4 FORMAT XML SETTINGS optimize_trivial_count_query = 0, optimize_use_implicit_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:24.676137 [ 4172 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE c = 4. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:24.706194 [ 5110 ] {7451e402-c54b-45a2-a9fe-69892b00cd28} executeQuery: Code: 43. DB::Exception: First argument for function arrayFirst must be a function. Actual Array(Nothing): In scope SELECT arrayFirst([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 212, line 213) (in query: SELECT arrayFirst([], [], []);) 2025.06.13 15:48:24.744842 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFirst must be a function. Actual Array(Nothing): In scope SELECT arrayFirst([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:24.857519 [ 5110 ] {da293f00-4f26-4111-a191-a35f70875b61} executeQuery: Code: 43. DB::Exception: First argument for function arrayFirstIndex must be a function. Actual Array(Nothing): In scope SELECT arrayFirstIndex([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 213, line 214) (in query: SELECT arrayFirstIndex([], [], []);) 2025.06.13 15:48:24.882622 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFirstIndex must be a function. Actual Array(Nothing): In scope SELECT arrayFirstIndex([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:25.026821 [ 5110 ] {8176d77c-1c72-41c6-a898-d0a3ff1dd5a1} executeQuery: Code: 43. DB::Exception: First argument for function arrayFirstOrNull must be a function. Actual Array(Nothing): In scope SELECT arrayFirstOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 214, line 215) (in query: SELECT arrayFirstOrNull([], [], []);) 2025.06.13 15:48:25.063072 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFirstOrNull must be a function. Actual Array(Nothing): In scope SELECT arrayFirstOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:25.119685 [ 34370 ] {835801bb-b62f-403d-a573-9cb151751420} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00 million, current rows: 111.22 billion. (TOO_MANY_ROWS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39368) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 111222333444 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:626: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000003224e174 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:552: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003224c117 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003224a419 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:48:25.124705 [ 34370 ] {835801bb-b62f-403d-a573-9cb151751420} DynamicQueryHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00 million, current rows: 111.22 billion. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:626: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000003224e174 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:552: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003224c117 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003224a419 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:25.180309 [ 5110 ] {addc8e29-19e5-4042-92e6-01c6edb75fef} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 215, line 216) (in query: SELECT arrayFlatten([], [], []);) 2025.06.13 15:48:25.197690 [ 4172 ] {9f971bc2-77cc-4616-a674-3997202686e2} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE (a < 200) AND (c = 2). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58076) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: SELECT count() FROM composite_partition_key WHERE a < 200 AND c = 2 FORMAT XML SETTINGS optimize_trivial_count_query = 0, optimize_use_implicit_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:25.212851 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:25.240545 [ 4172 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE (a < 200) AND (c = 2). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:25.436955 [ 5110 ] {99d2aabb-5410-4ea1-983e-17627b52670c} executeQuery: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 216, line 217) (in query: SELECT arrayFold([], [], []);) 2025.06.13 15:48:25.447890 [ 8101 ] {7dfd4da4-44ce-48d3-8deb-3db5147b2413} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 922, line 922) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt64(-1) as r FORMAT CSV;) 2025.06.13 15:48:25.468294 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:25.478082 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:25.582120 [ 34370 ] {1414a717-b3a8-43c0-87d4-7390c71d2e90} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39376) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:48:25.590212 [ 34370 ] {1414a717-b3a8-43c0-87d4-7390c71d2e90} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:25.724415 [ 4172 ] {8af45ca8-9ee8-40ba-8e48-03b2e22c5c86} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE (a = 301) AND (b < 20). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58078) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: SELECT count() FROM composite_partition_key WHERE a = 301 AND b < 20 FORMAT XML SETTINGS optimize_trivial_count_query = 0, optimize_use_implicit_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:25.751648 [ 4172 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE (a = 301) AND (b < 20). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:25.790173 [ 5110 ] {d8e976c3-2334-4d19-9f41-c68d02199328} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 218, line 219) (in query: SELECT arrayJaccardIndex([], [], []);) 2025.06.13 15:48:25.828842 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:26.006421 [ 5110 ] {1f421638-835e-4d2c-9228-43a890f1f328} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 219, line 220) (in query: SELECT arrayJoin([], [], []);) 2025.06.13 15:48:26.028198 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:26.053571 [ 34370 ] {629c6ce3-99b6-4b1c-bc34-e85bbc2077ec} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39388) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:48:26.056604 [ 34370 ] {629c6ce3-99b6-4b1c-bc34-e85bbc2077ec} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:26.113341 [ 5110 ] {0b865db5-c187-401d-a715-5cb35e4dec48} executeQuery: Code: 43. DB::Exception: First argument for function arrayLast must be a function. Actual Array(Nothing): In scope SELECT arrayLast([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 220, line 221) (in query: SELECT arrayLast([], [], []);) 2025.06.13 15:48:26.122020 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayLast must be a function. Actual Array(Nothing): In scope SELECT arrayLast([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:26.302998 [ 4172 ] {b4ee7a80-da2b-4513-b573-63788ee42907} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE (b >= 12) AND (c = 2). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58090) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: SELECT count() FROM composite_partition_key WHERE b >= 12 AND c = 2 FORMAT XML SETTINGS optimize_trivial_count_query = 0, optimize_use_implicit_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:26.313214 [ 5110 ] {58cb1014-6748-4c31-a523-651885634424} executeQuery: Code: 43. DB::Exception: First argument for function arrayLastIndex must be a function. Actual Array(Nothing): In scope SELECT arrayLastIndex([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 221, line 222) (in query: SELECT arrayLastIndex([], [], []);) 2025.06.13 15:48:26.342809 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayLastIndex must be a function. Actual Array(Nothing): In scope SELECT arrayLastIndex([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:26.414829 [ 4172 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE (b >= 12) AND (c = 2). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:26.521640 [ 5110 ] {1c8e27a7-03c9-4753-bb93-aa8590e91d27} executeQuery: Code: 43. DB::Exception: First argument for function arrayLastOrNull must be a function. Actual Array(Nothing): In scope SELECT arrayLastOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 222, line 223) (in query: SELECT arrayLastOrNull([], [], []);) 2025.06.13 15:48:26.521722 [ 8101 ] {1502eb9a-b47c-470f-ad3e-05e5145d09c0} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 927, line 927) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) != N as r FORMAT CSV;) 2025.06.13 15:48:26.528707 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:26.529326 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayLastOrNull must be a function. Actual Array(Nothing): In scope SELECT arrayLastOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:26.649216 [ 5110 ] {2d6b7fad-b509-4f2a-b325-7d355f88b5b1} executeQuery: Code: 43. DB::Exception: First argument for function arrayMap must be a function. Actual Array(Nothing): In scope SELECT arrayMap([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 223, line 224) (in query: SELECT arrayMap([], [], []);) 2025.06.13 15:48:26.674301 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayMap must be a function. Actual Array(Nothing): In scope SELECT arrayMap([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:26.782321 [ 4172 ] {3b54ee7a-1665-471d-874e-dcdaf1dbe667} executeQuery: Code: 62. DB::Exception: Max query size exceeded (can be increased with the `max_query_size` setting): Syntax error: failed at position 1048577 (-): -. . (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39412) (in query: select 1 in (1, 1, ... (truncated 948624 characters)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:48:26.784454 [ 4172 ] {3b54ee7a-1665-471d-874e-dcdaf1dbe667} DynamicQueryHandler: Code: 62. DB::Exception: Max query size exceeded (can be increased with the `max_query_size` setting): Syntax error: failed at position 1048577 (-): -. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000017d0a563 4. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000033079612 5. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000330796ad 6. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29d752 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:26.796930 [ 5110 ] {1d43f569-5724-426f-b58f-1798678be683} executeQuery: Code: 43. DB::Exception: First argument for function arrayMax must be a function. Actual Array(Nothing): In scope SELECT arrayMax([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 224, line 225) (in query: SELECT arrayMax([], [], []);) 2025.06.13 15:48:26.805820 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayMax must be a function. Actual Array(Nothing): In scope SELECT arrayMax([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:26.852632 [ 34347 ] {9c6cc94c-9c68-4150-b0b1-f38a3c0d4c56} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE (a = 301) AND (b = 21) AND (c = 3). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58102) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: SELECT count() FROM composite_partition_key WHERE a = 301 AND b = 21 AND c = 3 FORMAT XML SETTINGS optimize_trivial_count_query = 0, optimize_use_implicit_projections = 0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:26.855522 [ 34370 ] {a7eab3bb-c2c9-4c78-bf1c-965da9d2dd54} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39398) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1048577 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:48:26.875937 [ 34370 ] {a7eab3bb-c2c9-4c78-bf1c-965da9d2dd54} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:26.888572 [ 5110 ] {484cdeda-5520-4581-aed1-309c3fd4e20c} executeQuery: Code: 43. DB::Exception: First argument for function arrayMin must be a function. Actual Array(Nothing): In scope SELECT arrayMin([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 225, line 226) (in query: SELECT arrayMin([], [], []);) 2025.06.13 15:48:26.928489 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayMin must be a function. Actual Array(Nothing): In scope SELECT arrayMin([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:26.971220 [ 34347 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE (a = 301) AND (b = 21) AND (c = 3). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:27.055191 [ 5110 ] {150338a4-4a88-4443-8482-1781ff43a75b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 3, should be 2: In scope SELECT arrayNormalizedGini([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 226, line 227) (in query: SELECT arrayNormalizedGini([], [], []);) 2025.06.13 15:48:27.082796 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 3, should be 2: In scope SELECT arrayNormalizedGini([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:27.201635 [ 5110 ] {8c80a423-00ab-4b2b-95d3-897f2327aedb} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nothing, should be a number: In scope SELECT arrayPRAUC([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 227, line 228) (in query: SELECT arrayPRAUC([], [], []);) 2025.06.13 15:48:27.213360 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nothing, should be a number: In scope SELECT arrayPRAUC([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:27.307285 [ 5110 ] {0a9993d4-5c17-4f47-a728-8b58a4ee7bb9} executeQuery: Code: 43. DB::Exception: First argument for function arrayPartialReverseSort must be a function. Actual Array(Nothing): In scope SELECT arrayPartialReverseSort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 228, line 229) (in query: SELECT arrayPartialReverseSort([], [], []);) 2025.06.13 15:48:27.319596 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayPartialReverseSort must be a function. Actual Array(Nothing): In scope SELECT arrayPartialReverseSort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:27.501286 [ 5110 ] {a32d31d6-baa7-4884-98ec-f46b93c6581c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of arguments of function arrayPartialShuffle (must be UInt or Int): In scope SELECT arrayPartialShuffle([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 229, line 230) (in query: SELECT arrayPartialShuffle([], [], []);) 2025.06.13 15:48:27.523312 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of arguments of function arrayPartialShuffle (must be UInt or Int): In scope SELECT arrayPartialShuffle([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:27.686795 [ 4172 ] {677fad23-f3c4-46e6-8e3b-5fbdd0b7226e} executeQuery: Code: 60. DB::Exception: Table test_11.composite_partition_key does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58110) (comment: 00636_partition_key_parts_pruning.sh) (query 1, line 1) (in query: DROP TABLE composite_partition_key), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:27.713800 [ 4172 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.composite_partition_key does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:27.768343 [ 8101 ] {aa3e20e1-6fa1-4946-9ac3-2364ba8882d8} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 932, line 932) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt8(1) as r FORMAT CSV;) 2025.06.13 15:48:27.794370 [ 5110 ] {84adf625-9b05-47b6-839b-28240e05de33} executeQuery: Code: 43. DB::Exception: First argument for function arrayPartialSort must be a function. Actual Array(Nothing): In scope SELECT arrayPartialSort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 230, line 231) (in query: SELECT arrayPartialSort([], [], []);) 2025.06.13 15:48:27.798076 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:27.820052 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayPartialSort must be a function. Actual Array(Nothing): In scope SELECT arrayPartialSort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:28.013074 [ 5110 ] {0314e9a8-f5d6-4f32-b375-8ade4eee9dd0} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 231, line 232) (in query: SELECT arrayPopBack([], [], []);) 2025.06.13 15:48:28.022388 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:28.188349 [ 5110 ] {18c2e4e9-ed55-482a-b78a-4c3b7beb200c} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 232, line 233) (in query: SELECT arrayPopFront([], [], []);) 2025.06.13 15:48:28.220517 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:28.465430 [ 5110 ] {dfc80eff-b20d-46d7-bb82-7bbaea8191c6} executeQuery: Code: 43. DB::Exception: First argument for function arrayProduct must be a function. Actual Array(Nothing): In scope SELECT arrayProduct([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 233, line 234) (in query: SELECT arrayProduct([], [], []);) 2025.06.13 15:48:28.505185 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayProduct must be a function. Actual Array(Nothing): In scope SELECT arrayProduct([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:28.618321 [ 5110 ] {d083d115-a17e-4b6a-ba29-a8da634f0143} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 234, line 235) (in query: SELECT arrayPushBack([], [], []);) 2025.06.13 15:48:28.641707 [ 4172 ] {1b5dab25-8706-4d82-bf72-45fa1b191856} 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.20286.altinityantalya (altinity build)) (from [::1]:58124) (comment: 03002_int_div_decimal_with_date_bug.sql) (query 1, line 1) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(3)'), today());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78eb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20b091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:48:28.647187 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:28.650842 [ 4172 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 3) and Date of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(3)'), today()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78eb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20b091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:48:28.801147 [ 5110 ] {a55742e4-2639-47aa-9442-89b3f7ced23b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 235, line 236) (in query: SELECT arrayPushFront([], [], []);) 2025.06.13 15:48:28.801301 [ 4172 ] {ba7ea5fd-5c54-403d-8b8c-3e19b1436cd7} 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.20286.altinityantalya (altinity build)) (from [::1]:58124) (comment: 03002_int_div_decimal_with_date_bug.sql) (query 2, line 2) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(3)'), toDate('2023-01-02'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78eb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20b091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:48:28.814597 [ 8101 ] {ac9bf0ff-8b65-4277-84e4-1dd99d890b55} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 937, line 937) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) < N as r FORMAT CSV;) 2025.06.13 15:48:28.817452 [ 4172 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 3) and Date of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(3)'), toDate('2023-01-02')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78eb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20b091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:48:28.820061 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:28.821430 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:28.929821 [ 4172 ] {e774b957-ccd8-4a30-acb1-b39b88734c7f} 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.20286.altinityantalya (altinity build)) (from [::1]:58124) (comment: 03002_int_div_decimal_with_date_bug.sql) (query 3, line 3) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDate32('2023-01-02 12:12:12'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78eb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20b091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:48:28.939594 [ 4172 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and Date32 of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDate32('2023-01-02 12:12:12')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78eb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20b091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:48:28.949681 [ 5110 ] {d7f013c5-2f4f-4c45-a295-2a9fa050f69b} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayROCAUC([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 236, line 237) (in query: SELECT arrayROCAUC([], [], []);) 2025.06.13 15:48:28.976023 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayROCAUC([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:29.029554 [ 4172 ] {3234ba2d-49b4-4ed3-ace9-fb052aa3a74a} 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.20286.altinityantalya (altinity build)) (from [::1]:58124) (comment: 03002_int_div_decimal_with_date_bug.sql) (query 4, line 4) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime('2023-01-02 12:12:12'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78eb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20b091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:48:29.037271 [ 4172 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and DateTime of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime('2023-01-02 12:12:12')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78eb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20b091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:48:29.105404 [ 5110 ] {3c081de0-475e-4504-96cb-61e03903ea39} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 237, line 238) (in query: SELECT arrayRandomSample([], [], []);) 2025.06.13 15:48:29.115961 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:29.140493 [ 4172 ] {655dcccb-7f8e-49e7-9bd0-0b30871249b3} 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.20286.altinityantalya (altinity build)) (from [::1]:58124) (comment: 03002_int_div_decimal_with_date_bug.sql) (query 5, line 5) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime64('2023-01-02 12:12:12.002', 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78eb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20b091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:48:29.159438 [ 4172 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and DateTime64(3) of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime64('2023-01-02 12:12:12.002', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001c78eb8b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c20b091 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:48:29.236370 [ 5110 ] {b7588693-a40a-448b-aac2-d78444eee924} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 238, line 239) (in query: SELECT arrayReduce([], [], []);) 2025.06.13 15:48:29.255999 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:29.366723 [ 5110 ] {fe2059fd-4399-4278-a64d-9de0cc36beb6} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduceInRanges must be constant string: name of aggregate function.: In scope SELECT arrayReduceInRanges([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 239, line 240) (in query: SELECT arrayReduceInRanges([], [], []);) 2025.06.13 15:48:29.398462 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduceInRanges must be constant string: name of aggregate function.: In scope SELECT arrayReduceInRanges([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:29.489160 [ 34347 ] {3594f6b3-5cf4-4d5b-8009-21a64c3f3498} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39432) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1048577 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:48:29.508745 [ 34347 ] {3594f6b3-5cf4-4d5b-8009-21a64c3f3498} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:29.580849 [ 5110 ] {50375a9f-0c48-4601-bce1-74d96f55803b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'size' to function 'arrayResize'. Expected: Number, got: Array(Nothing): In scope SELECT arrayResize([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 240, line 241) (in query: SELECT arrayResize([], [], []);) 2025.06.13 15:48:29.599949 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'size' to function 'arrayResize'. Expected: Number, got: Array(Nothing): In scope SELECT arrayResize([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:29.695960 [ 8101 ] {16052769-4140-4fde-ad17-5539dd110ed2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 942, line 942) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt8(-1) as r FORMAT CSV;) 2025.06.13 15:48:29.700460 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:29.720686 [ 5110 ] {35cbf1ed-e52f-4612-b993-14a3f63d5231} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 241, line 242) (in query: SELECT arrayReverse([], [], []);) 2025.06.13 15:48:29.728079 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:29.769691 [ 5110 ] {c431ca76-8d05-4f09-8f42-8b7c50ff1bbf} executeQuery: Code: 43. DB::Exception: First argument for function arrayReverseFill must be a function. Actual Array(Nothing): In scope SELECT arrayReverseFill([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 242, line 243) (in query: SELECT arrayReverseFill([], [], []);) 2025.06.13 15:48:29.777040 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReverseFill must be a function. Actual Array(Nothing): In scope SELECT arrayReverseFill([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:29.840703 [ 5110 ] {a2b54f96-2001-4cd3-9bc3-0072c499c3f2} executeQuery: Code: 43. DB::Exception: First argument for function arrayReverseSort must be a function. Actual Array(Nothing): In scope SELECT arrayReverseSort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 243, line 244) (in query: SELECT arrayReverseSort([], [], []);) 2025.06.13 15:48:29.846797 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReverseSort must be a function. Actual Array(Nothing): In scope SELECT arrayReverseSort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:29.953338 [ 5110 ] {53058027-d603-4e45-8fba-0ee592726af9} executeQuery: Code: 43. DB::Exception: First argument for function arrayReverseSplit must be a function. Actual Array(Nothing): In scope SELECT arrayReverseSplit([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 244, line 245) (in query: SELECT arrayReverseSplit([], [], []);) 2025.06.13 15:48:29.963952 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReverseSplit must be a function. Actual Array(Nothing): In scope SELECT arrayReverseSplit([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:30.004068 [ 5110 ] {b59aa2c5-3cfd-46cb-a489-19c00ae6958b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 245, line 246) (in query: SELECT arrayRotateLeft([], [], []);) 2025.06.13 15:48:30.022635 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:30.076610 [ 5110 ] {8e8eff41-dbe5-4dc3-8b45-bb6f42a580e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 246, line 247) (in query: SELECT arrayRotateRight([], [], []);) 2025.06.13 15:48:30.081675 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:30.099514 [ 4172 ] {e07a5fbb-7a69-434b-adee-9b95822d97ca} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39444) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1500001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:48:30.101806 [ 4172 ] {e07a5fbb-7a69-434b-adee-9b95822d97ca} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:30.110816 [ 5110 ] {319828df-cdf9-4bf1-9a74-9e990c1fac4c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function arrayShiftLeft, expected Native Integer: In scope SELECT arrayShiftLeft([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 247, line 248) (in query: SELECT arrayShiftLeft([], [], []);) 2025.06.13 15:48:30.116221 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function arrayShiftLeft, expected Native Integer: In scope SELECT arrayShiftLeft([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:30.143338 [ 8101 ] {34d83f3b-bc48-471d-8e39-c539fdff6b15} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 947, line 947) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) < N as r FORMAT CSV;) 2025.06.13 15:48:30.148938 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:30.162009 [ 5110 ] {5e95371e-56ca-4718-9cf7-585cdfc22dd2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function arrayShiftRight, expected Native Integer: In scope SELECT arrayShiftRight([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 248, line 249) (in query: SELECT arrayShiftRight([], [], []);) 2025.06.13 15:48:30.168149 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function arrayShiftRight, expected Native Integer: In scope SELECT arrayShiftRight([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:30.205212 [ 5110 ] {15430327-04ea-46f9-b4a7-99d1685b5bcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 249, line 250) (in query: SELECT arrayShingles([], [], []);) 2025.06.13 15:48:30.214627 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:30.345763 [ 5110 ] {62158d49-a48e-40ba-898f-2b81e09ed6de} executeQuery: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 3.: In scope SELECT arrayShuffle([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 250, line 251) (in query: SELECT arrayShuffle([], [], []);) 2025.06.13 15:48:30.354706 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 3.: In scope SELECT arrayShuffle([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:30.523902 [ 5110 ] {e28b68a5-b000-42b3-9220-a9fd80fbfb76} executeQuery: Code: 43. DB::Exception: Argument 1 for function arraySlice must be integer but it has type Array(Nothing).: In scope SELECT arraySlice([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 251, line 252) (in query: SELECT arraySlice([], [], []);) 2025.06.13 15:48:30.533760 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 for function arraySlice must be integer but it has type Array(Nothing).: In scope SELECT arraySlice([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:30.601949 [ 5110 ] {1a90aa30-7167-4ea0-88b4-247bf939551b} executeQuery: Code: 43. DB::Exception: First argument for function arraySort must be a function. Actual Array(Nothing): In scope SELECT arraySort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 252, line 253) (in query: SELECT arraySort([], [], []);) 2025.06.13 15:48:30.609138 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arraySort must be a function. Actual Array(Nothing): In scope SELECT arraySort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:30.657100 [ 5110 ] {4745ceb5-a8b0-4a20-a14b-bf8b0b550c5b} executeQuery: Code: 43. DB::Exception: First argument for function arraySplit must be a function. Actual Array(Nothing): In scope SELECT arraySplit([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 253, line 254) (in query: SELECT arraySplit([], [], []);) 2025.06.13 15:48:30.664738 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arraySplit must be a function. Actual Array(Nothing): In scope SELECT arraySplit([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:30.674897 [ 4172 ] {b0b418e1-5d5d-458c-9148-c3c22f7d787a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39452) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1500001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:48:30.677377 [ 8101 ] {92effd84-e62d-4228-b321-962c5dc321bc} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 952, line 952) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt16(1) as r FORMAT CSV;) 2025.06.13 15:48:30.678608 [ 4172 ] {b0b418e1-5d5d-458c-9148-c3c22f7d787a} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:30.683165 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:30.724908 [ 5110 ] {0491bc03-1bdf-4808-b2c7-3d7e635775d6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayStringConcat'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT arrayStringConcat([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 254, line 255) (in query: SELECT arrayStringConcat([], [], []);) 2025.06.13 15:48:30.733830 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayStringConcat'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT arrayStringConcat([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:30.749465 [ 5978 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:30.794573 [ 5110 ] {537ded65-2d27-4c15-8a61-54cb028e4194} executeQuery: Code: 43. DB::Exception: First argument for function arraySum must be a function. Actual Array(Nothing): In scope SELECT arraySum([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 255, line 256) (in query: SELECT arraySum([], [], []);) 2025.06.13 15:48:30.802910 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arraySum must be a function. Actual Array(Nothing): In scope SELECT arraySum([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:31.091996 [ 5110 ] {9cc223f6-7186-482c-9ad3-9c632b47df96} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 259, line 260) (in query: SELECT arrayWithConstant([], [], []);) 2025.06.13 15:48:31.099356 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:31.189746 [ 34347 ] {d68fbbbd-0ca3-47c7-8562-40f5ac4f7f03} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=895, jobs=868). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58126) (comment: 02160_monthname.sql) (query 10, line 55) (in query: WITH toDate('2021-10-14') AS date_value, toDateTime('2021-10-14 11:22:33') AS date_time_value, toDateTime64('2021-10-14 11:22:33', 3) AS date_time_64_value SELECT monthName(date_value), monthName(date_time_value), monthName(date_time_64_value);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:48:31.229829 [ 34347 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=895, jobs=868). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:48:31.458596 [ 5110 ] {0c1ea0a9-8a8b-4241-a25c-2f26b95fd95d} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 262, line 263) (in query: SELECT array_agg([], [], []);) 2025.06.13 15:48:31.477013 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:31.573051 [ 5110 ] {0ccd1e7f-9a12-4597-b391-f76f89b64101} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 263, line 264) (in query: SELECT array_concat_agg([], [], []);) 2025.06.13 15:48:31.591452 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:31.597639 [ 8101 ] {0e5df5f2-2c8b-4404-aa43-b886ea577b98} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 957, line 957) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) < N as r FORMAT CSV;) 2025.06.13 15:48:31.618378 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:31.700979 [ 5110 ] {2ab44294-129b-482a-8fa8-d1e2f1587150} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 264, line 265) (in query: SELECT ascii([], [], []);) 2025.06.13 15:48:31.710462 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:31.783506 [ 5110 ] {05372abd-7dac-439b-8059-a040c8d47766} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 265, line 266) (in query: SELECT asin([], [], []);) 2025.06.13 15:48:31.791466 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:31.847440 [ 5110 ] {ca260218-22a9-4aca-ac0b-d4b0e772cee9} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 266, line 267) (in query: SELECT asinh([], [], []);) 2025.06.13 15:48:31.860819 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:31.910074 [ 5110 ] {8266c937-977e-4203-8932-f238e4188d1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 267, line 268) (in query: SELECT assumeNotNull([], [], []);) 2025.06.13 15:48:31.916427 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:31.975599 [ 5110 ] {d784b600-a146-4b44-9e8a-2ad849187848} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 268, line 269) (in query: SELECT atan([], [], []);) 2025.06.13 15:48:31.986307 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:32.004318 [ 4172 ] {5763cdef-431c-450b-83d7-656f18fc3593} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 4, should be 1: In scope SELECT materialize([(NULL, '11\01111111\011111', '1111')]) AS t, (t[1048576]).2, materialize(-2147483648), (t[-2147483648]).1 GROUP BY materialize([(NULL, '1')]), '', (materialize((t[1023]).2), (materialize(''), (t[2147483647]).1, materialize(9223372036854775807)), (materialize(''), materialize(NULL, 2147483647, t[65535], 256)), materialize(NULL)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58138) (comment: 03218_materialize_msan.sql) (query 2, line 3) (in query: SELECT materialize([(NULL, '11\01111111\011111', '1111')]) AS t, (t[1048576]).2, materialize(-2147483648), (t[-2147483648]).1 GROUP BY materialize([(NULL, '1')]), '', (materialize((t[1023]).2), (materialize(''), (t[2147483647]).1, materialize(9223372036854775807)), (materialize(''), materialize(NULL, 2147483647, t[65535], 256)), materialize(NULL)) ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002aceb2a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4227: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x000000002cc49279 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9df5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:48:32.011407 [ 4172 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 4, should be 1: In scope SELECT materialize([(NULL, '11\01111111\011111', '1111')]) AS t, (t[1048576]).2, materialize(-2147483648), (t[-2147483648]).1 GROUP BY materialize([(NULL, '1')]), '', (materialize((t[1023]).2), (materialize(''), (t[2147483647]).1, materialize(9223372036854775807)), (materialize(''), materialize(NULL, 2147483647, t[65535], 256)), materialize(NULL)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002aceb2a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceb118 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4227: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x000000002cc49279 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5618: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9df5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:48:32.036207 [ 5110 ] {a766bddb-2aa9-49f5-802b-644dcff3c5c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 269, line 270) (in query: SELECT atan2([], [], []);) 2025.06.13 15:48:32.163176 [ 8101 ] {7cceb0c8-bf49-48cc-b02d-487f780f08f3} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 962, line 962) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt16(-1) as r FORMAT CSV;) 2025.06.13 15:48:32.173464 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:32.178194 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:32.253000 [ 5110 ] {3461f7f0-9d0c-47f3-a08d-3a3d60d9cdff} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 270, line 271) (in query: SELECT atanh([], [], []);) 2025.06.13 15:48:32.271380 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:32.316976 [ 5110 ] {36e307fc-3575-444c-a14b-c6df8f9c1f3d} executeQuery: Code: 42. DB::Exception: Aggregate function avg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 271, line 272) (in query: SELECT avg([], [], []);) 2025.06.13 15:48:32.333172 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function avg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:32.374323 [ 5110 ] {378b4ed8-ca2f-448c-9c40-ea05a18a792a} executeQuery: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 272, line 273) (in query: SELECT avgWeighted([], [], []);) 2025.06.13 15:48:32.383343 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:32.425036 [ 5110 ] {efb6a795-42c5-4145-93b5-33e1104b5575} executeQuery: Code: 43. DB::Exception: All arguments for function bar must be numeric.: In scope SELECT bar([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 273, line 274) (in query: SELECT bar([], [], []);) 2025.06.13 15:48:32.430256 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: All arguments for function bar must be numeric.: In scope SELECT bar([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:32.458701 [ 6234 ] {1d320dd5-ccd4-4759-960f-2a5b890ac602} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.82 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39454) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 5000000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:48:32.465237 [ 6234 ] {1d320dd5-ccd4-4759-960f-2a5b890ac602} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.82 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:32.485542 [ 5110 ] {0492b7b0-90ab-43f7-ac8f-6e3305363253} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 274, line 275) (in query: SELECT base58Decode([], [], []);) 2025.06.13 15:48:32.492325 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:32.518232 [ 5110 ] {0ee997a1-bcc2-45e2-aeca-db93cf0fc3b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 275, line 276) (in query: SELECT base58Encode([], [], []);) 2025.06.13 15:48:32.523683 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:32.558345 [ 5110 ] {1f4e1ac5-b0a4-4158-b4a2-37abf7f591e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 276, line 277) (in query: SELECT base64Decode([], [], []);) 2025.06.13 15:48:32.566169 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:32.648284 [ 5110 ] {bc3e2014-4a05-4248-b156-bd275645a842} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 277, line 278) (in query: SELECT base64Encode([], [], []);) 2025.06.13 15:48:32.660875 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:32.729075 [ 5110 ] {4238d4d3-1017-41fc-a906-2081beb389af} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 278, line 279) (in query: SELECT base64URLDecode([], [], []);) 2025.06.13 15:48:32.736212 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:32.738956 [ 8101 ] {419e6844-9615-4441-bbaa-af9686306c0c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 967, line 967) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) < N as r FORMAT CSV;) 2025.06.13 15:48:32.747181 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:32.814490 [ 5110 ] {ce0591e7-c19f-4b8a-9a8a-14f215a35612} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 279, line 280) (in query: SELECT base64URLEncode([], [], []);) 2025.06.13 15:48:32.851136 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:32.965305 [ 5163 ] {031ba380-ee8b-461a-a301-9838975b12ba} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50694) (comment: 01018_ip_dictionary_long.sql) (query 69, line 119) (in query: DROP DICTIONARY IF EXISTS test_15.dict_ipv4_trie), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:48:32.980903 [ 34322 ] {eaffb410-ca0a-439f-a6e9-4aa08ba23cba} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49556) (comment: 02713_sequence_match_serialization_fix.sql) (in query: DROP DATABASE IF EXISTS test_kfegq2ha SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:48:32.990946 [ 34322 ] {eaffb410-ca0a-439f-a6e9-4aa08ba23cba} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:33.017543 [ 5163 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:48:33.023043 [ 5110 ] {3f8e342d-d4b5-4f0b-9da6-52dd9c4a6e96} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 280, line 281) (in query: SELECT basename([], [], []);) 2025.06.13 15:48:33.044195 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:33.127699 [ 5110 ] {bd9cc421-337b-4357-9bf5-44443b7c7bef} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 281, line 282) (in query: SELECT bin([], [], []);) 2025.06.13 15:48:33.141326 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:33.141221 [ 6234 ] {60f7ccd2-2f62-4710-b7a7-5714d10b6a08} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60964) (comment: 02713_sequence_match_serialization_fix.sql) (in query: DROP DATABASE IF EXISTS test_kfegq2ha SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:48:33.156532 [ 6234 ] {60f7ccd2-2f62-4710-b7a7-5714d10b6a08} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:33.246564 [ 5110 ] {19c97c6d-f31e-46cf-8607-9efb17c496be} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 282, line 283) (in query: SELECT bitAnd([], [], []);) 2025.06.13 15:48:33.265474 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:33.432621 [ 5110 ] {d32c2ee4-afbd-49de-8c6a-4d9e2fa414bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 283, line 284) (in query: SELECT bitCount([], [], []);) 2025.06.13 15:48:33.457293 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:33.478433 [ 8101 ] {a82e9ba6-9570-476f-8c4b-6a5fc690b17b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 972, line 972) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt32(1) as r FORMAT CSV;) 2025.06.13 15:48:33.499235 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:33.615839 [ 5110 ] {78b36def-4478-4ca5-bf6f-a7bc3c926a92} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 284, line 285) (in query: SELECT bitHammingDistance([], [], []);) 2025.06.13 15:48:33.630550 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:33.698518 [ 5110 ] {a12dac5d-f33a-4b05-ab3f-708ffcd23303} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 285, line 286) (in query: SELECT bitNot([], [], []);) 2025.06.13 15:48:33.705970 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:34.060942 [ 5110 ] {3150555c-0a66-4c17-9005-21f5b051dd9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 286, line 287) (in query: SELECT bitOr([], [], []);) 2025.06.13 15:48:34.095343 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:34.274901 [ 5110 ] {40de7581-585f-43b9-8c80-3a7c429bc66b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 287, line 288) (in query: SELECT bitPositionsToArray([], [], []);) 2025.06.13 15:48:34.285142 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:34.384452 [ 5110 ] {2f1c83fd-aec4-493a-aecb-1e846d2159ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 288, line 289) (in query: SELECT bitRotateLeft([], [], []);) 2025.06.13 15:48:34.393045 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:34.541306 [ 5110 ] {8bc05cd3-3ffe-4eff-b6ea-4b7131957982} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 289, line 290) (in query: SELECT bitRotateRight([], [], []);) 2025.06.13 15:48:34.561280 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:34.732654 [ 5110 ] {89400e65-d078-4d66-8a7f-ef0a406d242f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 290, line 291) (in query: SELECT bitShiftLeft([], [], []);) 2025.06.13 15:48:34.755950 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:34.771271 [ 8101 ] {db393bb0-0085-4ef4-91e6-6ad031f6f9c2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 977, line 977) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) < N as r FORMAT CSV;) 2025.06.13 15:48:34.779761 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:34.854004 [ 5110 ] {f41ced99-2242-4326-b532-5b9dfa7494b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 291, line 292) (in query: SELECT bitShiftRight([], [], []);) 2025.06.13 15:48:34.865797 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:34.866380 [ 34347 ] {2b23a4b5-6366-4b6a-a59a-9fb492b28edd} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.82 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39458) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 5000000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:48:34.874316 [ 34347 ] {2b23a4b5-6366-4b6a-a59a-9fb492b28edd} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.82 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:34.964536 [ 5110 ] {590b9d1b-f57b-482f-80eb-9b676b37497d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'bitSlice'. Expected: String, got: Array(Nothing): In scope SELECT bitSlice([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 292, line 293) (in query: SELECT bitSlice([], [], []);) 2025.06.13 15:48:34.983666 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'bitSlice'. Expected: String, got: Array(Nothing): In scope SELECT bitSlice([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:35.096839 [ 5110 ] {89e99b82-ca47-4336-b82b-e62a38bf4128} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 293, line 294) (in query: SELECT bitTest([], [], []);) 2025.06.13 15:48:35.112900 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:35.191718 [ 5110 ] {cd5e4b06-3a98-4843-b908-c437e3ae6a8d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function bitTestAll: In scope SELECT bitTestAll([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 294, line 295) (in query: SELECT bitTestAll([], [], []);) 2025.06.13 15:48:35.205115 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function bitTestAll: In scope SELECT bitTestAll([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:35.286092 [ 5110 ] {856d3ded-cf07-4297-8ebe-5e18ba4d9ebb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function bitTestAny: In scope SELECT bitTestAny([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 295, line 296) (in query: SELECT bitTestAny([], [], []);) 2025.06.13 15:48:35.294413 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function bitTestAny: In scope SELECT bitTestAny([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:35.333693 [ 8101 ] {2904f5eb-c3b7-4267-86c9-54061365b81b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 982, line 982) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt32(-1) as r FORMAT CSV;) 2025.06.13 15:48:35.346555 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:35.381732 [ 5110 ] {5077c75e-d46f-4d19-9ca2-8510b05ebdfc} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 296, line 297) (in query: SELECT bitXor([], [], []);) 2025.06.13 15:48:35.391944 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:35.530157 [ 5110 ] {5abcef57-80c3-4c71-98be-5a536f63d9c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 297, line 298) (in query: SELECT bitmapAnd([], [], []);) 2025.06.13 15:48:35.542576 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:35.845482 [ 5110 ] {fcf72b08-66ce-4c93-b9fa-e6c9ca2ac429} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 298, line 299) (in query: SELECT bitmapAndCardinality([], [], []);) 2025.06.13 15:48:35.865404 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:36.016346 [ 5110 ] {aaae7e0a-87ae-49ef-b6ee-453e56dfbeef} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 299, line 300) (in query: SELECT bitmapAndnot([], [], []);) 2025.06.13 15:48:36.035683 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:36.253560 [ 5110 ] {339c78f0-e6c7-4fd6-9e82-50279fcfb729} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 300, line 301) (in query: SELECT bitmapAndnotCardinality([], [], []);) 2025.06.13 15:48:36.268165 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:36.475911 [ 5110 ] {25468953-af0c-4662-a2fe-e28f64139d6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 301, line 302) (in query: SELECT bitmapBuild([], [], []);) 2025.06.13 15:48:36.504681 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:36.557067 [ 8101 ] {d8e5aeb7-e92e-43b7-af9a-87b0adbcf0bf} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 987, line 987) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) < N as r FORMAT CSV;) 2025.06.13 15:48:36.595895 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:36.653748 [ 5110 ] {39dca31f-0abd-4211-9ce0-304ec7f2a32a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 302, line 303) (in query: SELECT bitmapCardinality([], [], []);) 2025.06.13 15:48:36.669349 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:36.805209 [ 5110 ] {1aae7e49-b743-4611-a252-e194251130eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 303, line 304) (in query: SELECT bitmapContains([], [], []);) 2025.06.13 15:48:36.888812 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:37.000405 [ 5110 ] {5e2de15b-66e2-4226-9ee1-2eeba64d27d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 304, line 305) (in query: SELECT bitmapHasAll([], [], []);) 2025.06.13 15:48:37.020171 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:37.048829 [ 34342 ] {3688e1a8-17f1-4cc5-8b68-6d08dfbad113} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.82 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34804) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 5000000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:48:37.055484 [ 34342 ] {3688e1a8-17f1-4cc5-8b68-6d08dfbad113} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.82 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002c3ef4af 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee8ee 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000031dd830e 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:37.197764 [ 5110 ] {7b24cc65-5d5d-481c-baec-8b4e3f880e04} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 305, line 306) (in query: SELECT bitmapHasAny([], [], []);) 2025.06.13 15:48:37.249994 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:37.398221 [ 5110 ] {648eb4d9-326e-4edc-b45d-2ada37766968} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 306, line 307) (in query: SELECT bitmapMax([], [], []);) 2025.06.13 15:48:37.423410 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:37.488487 [ 5110 ] {42d34a7a-4919-4535-81e8-94bcdf9b38ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 307, line 308) (in query: SELECT bitmapMin([], [], []);) 2025.06.13 15:48:37.497722 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:37.593927 [ 8101 ] {b631aacb-e25a-4084-b76a-de66edd4bc28} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 992, line 992) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt64(1) as r FORMAT CSV;) 2025.06.13 15:48:37.616261 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:37.637522 [ 5110 ] {fda33152-41d5-49f1-afa9-63cc054ac717} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 308, line 309) (in query: SELECT bitmapOr([], [], []);) 2025.06.13 15:48:37.648988 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:37.724030 [ 5110 ] {de398d78-c2e0-4818-a97b-bc5d497b23f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 309, line 310) (in query: SELECT bitmapOrCardinality([], [], []);) 2025.06.13 15:48:37.740727 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:37.865280 [ 5110 ] {25018d80-cec9-4c09-86e2-e00d2f6d0d8d} executeQuery: Code: 43. DB::Exception: First argument for function bitmapSubsetInRange must be a bitmap but it has type Array(Nothing).: In scope SELECT bitmapSubsetInRange([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 310, line 311) (in query: SELECT bitmapSubsetInRange([], [], []);) 2025.06.13 15:48:37.875015 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapSubsetInRange must be a bitmap but it has type Array(Nothing).: In scope SELECT bitmapSubsetInRange([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:37.984185 [ 5110 ] {267f86e4-63c8-4538-92d7-b63a0d737537} executeQuery: Code: 43. DB::Exception: First argument for function bitmapSubsetLimit must be a bitmap but it has type Array(Nothing).: In scope SELECT bitmapSubsetLimit([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 311, line 312) (in query: SELECT bitmapSubsetLimit([], [], []);) 2025.06.13 15:48:38.003426 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapSubsetLimit must be a bitmap but it has type Array(Nothing).: In scope SELECT bitmapSubsetLimit([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:38.122792 [ 5110 ] {40b0a48a-247e-48a3-aa7a-4ce02c1ab102} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 312, line 313) (in query: SELECT bitmapToArray([], [], []);) 2025.06.13 15:48:38.131120 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:38.222387 [ 5110 ] {2c0b8b43-27e2-4ba0-9dca-6a49b531a5a0} executeQuery: Code: 43. DB::Exception: First argument for function bitmapTransform must be a bitmap but it has type Array(Nothing).: In scope SELECT bitmapTransform([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 313, line 314) (in query: SELECT bitmapTransform([], [], []);) 2025.06.13 15:48:38.231814 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapTransform must be a bitmap but it has type Array(Nothing).: In scope SELECT bitmapTransform([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:38.313365 [ 5110 ] {630953a0-3032-4d00-8d61-2daf9e788835} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 314, line 315) (in query: SELECT bitmapXor([], [], []);) 2025.06.13 15:48:38.353441 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:38.434550 [ 8101 ] {021b11be-68d8-4d0b-a736-5a4ce2682427} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 997, line 997) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) < N as r FORMAT CSV;) 2025.06.13 15:48:38.438875 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:38.443327 [ 5110 ] {6fc43d16-9776-47a4-b9dd-bd8c3b28282d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 315, line 316) (in query: SELECT bitmapXorCardinality([], [], []);) 2025.06.13 15:48:38.452257 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:38.601043 [ 5110 ] {3df08e57-6e4d-4656-9fef-c3d583bcdaab} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 316, line 317) (in query: SELECT bitmaskToArray([], [], []);) 2025.06.13 15:48:38.615680 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:38.735626 [ 5110 ] {d877ae80-91aa-4db3-9fb6-d36bd2ea329e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 317, line 318) (in query: SELECT bitmaskToList([], [], []);) 2025.06.13 15:48:38.746146 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:38.870128 [ 5110 ] {cd535397-8a18-4a2f-b70e-84318aa5143c} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 318, line 319) (in query: SELECT blockNumber([], [], []);) 2025.06.13 15:48:38.877027 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:39.151311 [ 8101 ] {e9fda963-56a8-42dc-81f9-e235553daa12} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1002, line 1002) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt64(-1) as r FORMAT CSV;) 2025.06.13 15:48:39.176598 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:39.201174 [ 5110 ] {769355af-dcad-4e89-80ce-9a6b90ced453} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 320, line 321) (in query: SELECT blockSize([], [], []);) 2025.06.13 15:48:39.267068 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:39.278355 [ 3821 ] {43880789-397d-4866-ad48-0e29557bb89c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58906) (comment: 02366_kql_summarize.sql) (query 52, line 90) (in query: Customers | sort by FirstName | summarize count() by Occupation | sort by Occupation;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181b22b 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:48:39.293602 [ 3821 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181b22b 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:48:39.417986 [ 5110 ] {4d002ecb-d526-4489-89ac-10c78ce54276} executeQuery: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 321, line 322) (in query: SELECT boundingRatio([], [], []);) 2025.06.13 15:48:39.424166 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:39.587836 [ 5110 ] {5aaf6e18-fe98-4648-993d-ef721bc9a9ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 322, line 323) (in query: SELECT buildId([], [], []);) 2025.06.13 15:48:39.610094 [ 34342 ] {47df44ef-1eed-44c8-84fa-c0e3e3138313} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32818) (comment: 02366_kql_summarize.sql) (in query: DROP DATABASE IF EXISTS test_rfkhyf7i SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:48:39.610768 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:39.621939 [ 34342 ] {47df44ef-1eed-44c8-84fa-c0e3e3138313} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:39.731644 [ 8430 ] {75ff42fe-c090-485b-b6a8-a024f419181a} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239910e3 9. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017d46c46 10. ./src/Common/PODArray.h:228: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa595ce 11. ./build_docker/./src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa38684 12. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000002faa243d 13. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000002faa5006 14. ./build_docker/./src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x00000000317b6984 15. ./build_docker/./src/Server/TCPHandler.cpp:2483: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca320 16. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 17. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:39.739218 [ 5110 ] {bc9e21fa-b0ad-4c3e-b8e9-f7df29e913fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 323, line 324) (in query: SELECT byteHammingDistance([], [], []);) 2025.06.13 15:48:39.753107 [ 8430 ] {75ff42fe-c090-485b-b6a8-a024f419181a} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56360) (comment: 01785_parallel_formatting_memory.sh) (query 1, line 1) (in query: SELECT range(65535) FROM system.one ARRAY JOIN range(65536) AS number), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239910e3 9. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017d46c46 10. ./src/Common/PODArray.h:228: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa595ce 11. ./build_docker/./src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa38684 12. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000002faa243d 13. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000002faa5006 14. ./build_docker/./src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x00000000317b6984 15. ./build_docker/./src/Server/TCPHandler.cpp:2483: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca320 16. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 17. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:39.776609 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:39.798320 [ 8430 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239910e3 9. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017d46c46 10. ./src/Common/PODArray.h:228: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa595ce 11. ./build_docker/./src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa38684 12. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000002faa243d 13. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000002faa5006 14. ./build_docker/./src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x00000000317b6984 15. ./build_docker/./src/Server/TCPHandler.cpp:2483: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca320 16. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 17. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:39.834878 [ 5005 ] {62fd5977-d66f-447a-a5d5-183fa1f769f9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32838) (comment: 02366_kql_summarize.sql) (in query: DROP DATABASE IF EXISTS test_rfkhyf7i SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:48:39.846809 [ 5005 ] {62fd5977-d66f-447a-a5d5-183fa1f769f9} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:40.089816 [ 5110 ] {efe6493e-278b-4356-acf8-e3447149151f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT byteSlice([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 325, line 326) (in query: SELECT byteSlice([], [], []);) 2025.06.13 15:48:40.096719 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT byteSlice([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:40.191970 [ 8101 ] {a1e4a102-0b94-4ad8-9054-82e16e313733} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1007, line 1007) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) < N as r FORMAT CSV;) 2025.06.13 15:48:40.196153 [ 5110 ] {e116b237-64ed-46a6-8566-75c0ff582ea5} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 326, line 327) (in query: SELECT byteSwap([], [], []);) 2025.06.13 15:48:40.207861 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:40.217910 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:40.258745 [ 7279 ] {8a6c29a5-3c88-4758-936c-97416f2f2ee4} executeQuery: Code: 456. DB::Exception: Substitution `n` is not set. (UNKNOWN_QUERY_PARAMETER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56382) (comment: 02377_extend_protocol_with_query_parameters.sh) (query 1, line 1) (in query: select {n: UInt8} -- { serverError 456 }), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:71: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x000000002e283c36 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:80: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x000000002e281c7d 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1042: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29e313 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:48:40.274051 [ 7279 ] {} TCPHandler: Code: 456. DB::Exception: Substitution `n` is not set. (UNKNOWN_QUERY_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:71: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x000000002e283c36 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:80: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x000000002e281c7d 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x000000002e283a16 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1042: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e29e313 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:48:40.338817 [ 5110 ] {7d7b87fa-9d68-4c67-8a67-f8ad35f5a82c} executeQuery: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope SELECT caseWithExpr([], [], []). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 327, line 328) (in query: SELECT caseWithExpr([], [], []);) 2025.06.13 15:48:40.369782 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope SELECT caseWithExpr([], [], []). (BAD_ARGUMENTS) 2025.06.13 15:48:40.471415 [ 18602 ] {1a4e7979-a092-4193-be76-4e734fe2944d} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239910e3 9. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017d46c46 10. ./src/Common/PODArray.h:228: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa595ce 11. ./build_docker/./src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa38684 12. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000002faa243d 13. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000002faa5006 14. ./build_docker/./src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x00000000317b6984 15. ./build_docker/./src/Server/TCPHandler.cpp:2483: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca320 16. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 17. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:40.494547 [ 18602 ] {1a4e7979-a092-4193-be76-4e734fe2944d} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56384) (comment: 01785_parallel_formatting_memory.sh) (query 1, line 1) (in query: SELECT range(65535) FROM system.one ARRAY JOIN range(65536) AS number), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239910e3 9. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017d46c46 10. ./src/Common/PODArray.h:228: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa595ce 11. ./build_docker/./src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa38684 12. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000002faa243d 13. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000002faa5006 14. ./build_docker/./src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x00000000317b6984 15. ./build_docker/./src/Server/TCPHandler.cpp:2483: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca320 16. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 17. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:40.526676 [ 18602 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239910e3 9. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017d46c46 10. ./src/Common/PODArray.h:228: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa595ce 11. ./build_docker/./src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa38684 12. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000002faa243d 13. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000002faa5006 14. ./build_docker/./src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x00000000317b6984 15. ./build_docker/./src/Server/TCPHandler.cpp:2483: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca320 16. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 17. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:40.532180 [ 5110 ] {5777059a-2ae9-47d1-ae20-47b28a5c84fe} executeQuery: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope SELECT caseWithExpression([], [], []). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 328, line 329) (in query: SELECT caseWithExpression([], [], []);) 2025.06.13 15:48:40.547948 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope SELECT caseWithExpression([], [], []). (BAD_ARGUMENTS) 2025.06.13 15:48:40.672577 [ 5110 ] {a492af72-e74b-4306-adc4-623baba5bf97} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT caseWithoutExpr([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 329, line 330) (in query: SELECT caseWithoutExpr([], [], []);) 2025.06.13 15:48:40.768061 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT caseWithoutExpr([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:40.965775 [ 5110 ] {87705f8f-983f-48ac-9176-e93472874ec2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT caseWithoutExpression([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 330, line 331) (in query: SELECT caseWithoutExpression([], [], []);) 2025.06.13 15:48:41.102436 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT caseWithoutExpression([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:41.383981 [ 5110 ] {bdd5574c-c1f2-491f-b782-6502633f750b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 331, line 332) (in query: SELECT catboostEvaluate([], [], []);) 2025.06.13 15:48:41.404330 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:41.412116 [ 8101 ] {34e426a7-7a3f-4a6a-b794-292bf4fd33c6} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1012, line 1012) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt8(1) as r FORMAT CSV;) 2025.06.13 15:48:41.423861 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:41.590006 [ 5110 ] {6936ca82-c0c6-4bdf-be53-89f4e75501c9} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 332, line 333) (in query: SELECT categoricalInformationValue([], [], []);) 2025.06.13 15:48:41.602392 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:41.719704 [ 34342 ] {c89b0645-6db3-4cdd-b90e-9efcfa9fc249} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56438) (comment: 00900_orc_arrays_load.sh) (query 1, line 1) (in query: CREATE TABLE orc_arrays (arr1 Array(Int8), arr2 Array(UInt8), arr3 Array(Int16), arr4 Array(UInt16), arr5 Array(Int32), arr6 Array(UInt32), arr7 Array(Int64), arr8 Array(UInt64), arr9 Array(String), arr10 Array(FixedString(4)), arr11 Array(Float32), arr12 Array(Float64), arr13 Array(Date), arr14 Array(Datetime), arr15 Array(Decimal(4, 2)), arr16 Array(Decimal(10, 2)), arr17 Array(Decimal(25, 2))) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:41.755415 [ 34342 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:41.835616 [ 5110 ] {332988c9-8590-4da2-a921-227a7b479d99} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 333, line 334) (in query: SELECT cbrt([], [], []);) 2025.06.13 15:48:41.895070 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:42.006656 [ 5110 ] {ebdf7888-50d1-4478-be03-5e38aca342eb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT ceil([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 334, line 335) (in query: SELECT ceil([], [], []);) 2025.06.13 15:48:42.015123 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT ceil([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:42.105623 [ 5110 ] {7e5c971d-e268-4e92-a089-be1c1ade7108} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT ceiling([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 335, line 336) (in query: SELECT ceiling([], [], []);) 2025.06.13 15:48:42.115155 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT ceiling([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:42.229055 [ 5110 ] {51f48552-7c9e-4352-a082-ec2d1f7a0483} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 336, line 337) (in query: SELECT changeDay([], [], []);) 2025.06.13 15:48:42.258463 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:42.317135 [ 2860 ] {6ba38b22-8169-4da0-9816-7838c3e6ac07} executeQuery: Code: 60. DB::Exception: Table test_11.orc_arrays does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56462) (comment: 00900_orc_arrays_load.sh) (query 1, line 1) (in query: INSERT INTO orc_arrays VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:42.339582 [ 2860 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.orc_arrays does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:42.369725 [ 5110 ] {2fe1a931-445f-432b-9af0-97f46fb15a11} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 337, line 338) (in query: SELECT changeHour([], [], []);) 2025.06.13 15:48:42.382839 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:42.551734 [ 5110 ] {d4b0cbf3-a9da-45a3-9cda-332ae729e293} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 338, line 339) (in query: SELECT changeMinute([], [], []);) 2025.06.13 15:48:42.580686 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:42.602664 [ 8101 ] {a351b80a-8744-42e3-998a-3fb5707f0977} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1017, line 1017) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) <= N as r FORMAT CSV;) 2025.06.13 15:48:42.626531 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:42.703147 [ 5110 ] {3b8863ee-0f8d-4159-958c-36f22d5839e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 339, line 340) (in query: SELECT changeMonth([], [], []);) 2025.06.13 15:48:42.725537 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:42.819420 [ 5110 ] {48a36ca6-3b5b-4496-8d05-4d8a7d86d01c} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 340, line 341) (in query: SELECT changeSecond([], [], []);) 2025.06.13 15:48:42.819905 [ 8430 ] {a5db9932-4228-4da4-9d48-bdc1e76a1f93} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'orc_arrays' in scope SELECT * FROM orc_arrays. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56466) (comment: 00900_orc_arrays_load.sh) (query 1, line 1) (in query: SELECT * FROM orc_arrays FORMAT ORC), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:42.825200 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:42.838850 [ 8430 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'orc_arrays' in scope SELECT * FROM orc_arrays. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:42.962216 [ 5110 ] {3b77b7b4-ae89-4f4c-8471-df5c593bb80a} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 341, line 342) (in query: SELECT changeYear([], [], []);) 2025.06.13 15:48:42.989818 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:43.176607 [ 5110 ] {9045ccbc-6dab-4e20-9dd3-b2efdb638ce1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function char, must be Int, UInt or Float number: In scope SELECT char([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 342, line 343) (in query: SELECT char([], [], []);) 2025.06.13 15:48:43.196502 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function char, must be Int, UInt or Float number: In scope SELECT char([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:43.657384 [ 8101 ] {41f478d0-8286-4ec8-b407-2667c18fa576} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1022, line 1022) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt8(-1) as r FORMAT CSV;) 2025.06.13 15:48:43.671263 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:43.960231 [ 8430 ] {405884d4-b0f2-4bfb-84e0-b00a0ce90a15} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'orc_arrays' in scope SELECT * FROM orc_arrays. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52678) (comment: 00900_orc_arrays_load.sh) (query 1, line 1) (in query: SELECT * FROM orc_arrays), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:43.986623 [ 8430 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'orc_arrays' in scope SELECT * FROM orc_arrays. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:48:44.065055 [ 5110 ] {c2d3e13e-5968-46bf-8421-d693d00caeee} 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([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 346, line 347) (in query: SELECT compareSubstrings([], [], []);) 2025.06.13 15:48:44.077105 [ 5110 ] {} 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([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:44.540545 [ 8101 ] {92cba408-f100-4653-935f-56aa36c93fdf} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1027, line 1027) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) <= N as r FORMAT CSV;) 2025.06.13 15:48:44.545436 [ 4171 ] {accb1b3b-a56e-4f43-b36a-38ac9969564f} executeQuery: Code: 60. DB::Exception: Table test_11.orc_arrays does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52710) (comment: 00900_orc_arrays_load.sh) (query 1, line 1) (in query: DROP TABLE orc_arrays), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:44.547476 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:44.559277 [ 4171 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.orc_arrays does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0ed6 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca562a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:44.598034 [ 5110 ] {10655ffe-db9c-45b5-a861-e8e5cc4f029f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparator: In scope SELECT concatWithSeparator([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 349, line 350) (in query: SELECT concatWithSeparator([], [], []);) 2025.06.13 15:48:44.609265 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparator: In scope SELECT concatWithSeparator([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:44.722676 [ 5110 ] {b13504e1-00bf-4f22-84fa-81da4a7a8622} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparatorAssumeInjective: In scope SELECT concatWithSeparatorAssumeInjective([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 350, line 351) (in query: SELECT concatWithSeparatorAssumeInjective([], [], []);) 2025.06.13 15:48:44.730038 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparatorAssumeInjective: In scope SELECT concatWithSeparatorAssumeInjective([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:44.905186 [ 5110 ] {351b758a-df40-4a40-a80c-680436341ec3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparator: In scope SELECT concat_ws([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 351, line 352) (in query: SELECT concat_ws([], [], []);) 2025.06.13 15:48:44.910004 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparator: In scope SELECT concat_ws([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:45.242279 [ 5110 ] {459f07b3-51ec-4a79-b071-b370c5b9d3ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 352, line 353) (in query: SELECT connectionId([], [], []);) 2025.06.13 15:48:45.278918 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:45.332054 [ 5110 ] {12b2dca9-9580-488c-938d-65053f46bfd7} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 353, line 354) (in query: SELECT connection_id([], [], []);) 2025.06.13 15:48:45.342588 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:45.429121 [ 5110 ] {ec347fc9-b3f3-4405-aebc-e4fc18a6e0f5} executeQuery: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 354, line 355) (in query: SELECT contingency([], [], []);) 2025.06.13 15:48:45.437091 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:45.471134 [ 8430 ] {308e1dba-a4a1-424c-8b15-9fe7c981957c} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52744) (comment: 02377_optimize_sorting_by_input_stream_properties_2.sql) (query 2, line 2) (in query: CREATE TABLE tab (`x` UInt32, `y` UInt32) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 10377, min_bytes_for_wide_part = 149318480, 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 = 491626256, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 15302838, merge_max_block_size = 16284, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 7685382581, 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 = 22064458, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 30697, primary_key_compress_block_size = 11144, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:45.484737 [ 8430 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:45.544324 [ 5110 ] {d2319b48-20bc-4b0b-81be-e4421939bd02} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function convertCharset, must be String: In scope SELECT convertCharset([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 355, line 356) (in query: SELECT convertCharset([], [], []);) 2025.06.13 15:48:45.553904 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function convertCharset, must be String: In scope SELECT convertCharset([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:45.571659 [ 8101 ] {da00ae46-0ea3-4e17-aec4-6042b717d5f2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1032, line 1032) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt16(1) as r FORMAT CSV;) 2025.06.13 15:48:45.584519 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:45.624716 [ 9636 ] {84d41043-c320-432a-8577-9526927ce6ab} executeQuery: Code: 469. DB::Exception: Constraint `bogus` for table _temporary_and_external_tables.`_tmp_951b1950-ef47-4f5b-9e41-bfba84d0ee9c` (951b1950-ef47-4f5b-9e41-bfba84d0ee9c) is violated at row 1. Expression: (0). Column values: . (VIOLATED_CONSTRAINT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52718) (comment: 01358_constexpr_constraint.sql) (query 5, line 12) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5e9077 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031da1148 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:45.638963 [ 9636 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `bogus` for table _temporary_and_external_tables.`_tmp_951b1950-ef47-4f5b-9e41-bfba84d0ee9c` (951b1950-ef47-4f5b-9e41-bfba84d0ee9c) is violated at row 1. Expression: (0). Column values: . (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&) @ 0x000000002c5e9077 5. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000031da1148 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003183b9f6 13. ./build_docker/./src/Server/TCPHandler.cpp:1127: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000316b7d32 14. ./build_docker/./src/Server/TCPHandler.cpp:672: DB::TCPHandler::runImpl() @ 0x00000000316a4449 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:45.684368 [ 5110 ] {1cb0601b-24d7-4adf-aafe-4b8000470d61} executeQuery: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 356, line 357) (in query: SELECT corr([], [], []);) 2025.06.13 15:48:45.695069 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:45.769728 [ 5110 ] {93cad937-aa6f-4711-9cd1-b8351a6537f0} executeQuery: Code: 43. DB::Exception: Aggregate function corrMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 357, line 358) (in query: SELECT corrMatrix([], [], []);) 2025.06.13 15:48:45.795412 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function corrMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:45.901187 [ 5110 ] {37216fab-1115-4f42-8797-33b9a244aef8} executeQuery: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 358, line 359) (in query: SELECT corrStable([], [], []);) 2025.06.13 15:48:45.919513 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:46.007743 [ 5110 ] {be1a890d-b4af-4c52-ae1e-00343ce868da} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 359, line 360) (in query: SELECT cos([], [], []);) 2025.06.13 15:48:46.020622 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:46.091109 [ 5110 ] {ddb6089e-33f9-4db7-8c77-29334da25add} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 360, line 361) (in query: SELECT cosh([], [], []);) 2025.06.13 15:48:46.111022 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:46.167548 [ 7279 ] {e4e84dc5-cf7c-49b1-af34-485b2728dccf} executeQuery: Code: 57. DB::Exception: Table test_a3fhh47e.enums already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56410) (comment: 00294_shard_enums.sql) (query 20, line 45) (in query: create table enums (e Enum8('a' = 0, 'b' = 1, 'c' = 2, 'd' = 3)) engine = TinyLog;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:48:46.188232 [ 7279 ] {} TCPHandler: Code: 57. DB::Exception: Table test_a3fhh47e.enums already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:48:46.213723 [ 5110 ] {fb0b2189-0974-49bf-8d6c-613b80c17c84} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 361, line 362) (in query: SELECT cosineDistance([], [], []);) 2025.06.13 15:48:46.218490 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:46.288917 [ 8101 ] {65e4f8bf-e4a7-468d-ac53-778aec86820f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1037, line 1037) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) <= N as r FORMAT CSV;) 2025.06.13 15:48:46.293057 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:46.294992 [ 5110 ] {b3af1955-4ba4-48f2-b0d7-1e49b65156f1} executeQuery: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 362, line 363) (in query: SELECT count([], [], []);) 2025.06.13 15:48:46.304483 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:46.427212 [ 5110 ] {4752b3a9-29f7-4482-82c5-c358c6d4099b} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 363, line 364) (in query: SELECT countDigits([], [], []);) 2025.06.13 15:48:46.457114 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:46.534557 [ 5110 ] {1e8f693f-ddbf-443b-b724-5c6901f6e5c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 364, line 365) (in query: SELECT countEqual([], [], []);) 2025.06.13 15:48:46.546945 [ 3894 ] {72368d43-98ab-45b1-acd2-357f8f82b405} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52758) (comment: 01051_all_join_engine.sql) (query 6, line 8) (in query: CREATE TABLE t1 (x UInt32, str String) engine = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:46.555849 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:46.557321 [ 3894 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:46.640012 [ 5110 ] {0477dcc0-8ddb-49c3-a5c2-6752024bd965} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 365, line 366) (in query: SELECT countMatches([], [], []);) 2025.06.13 15:48:46.651917 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:46.781659 [ 5110 ] {1e5a24b8-694b-40b3-83ef-bb0db20de62e} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 366, line 367) (in query: SELECT countMatchesCaseInsensitive([], [], []);) 2025.06.13 15:48:46.816068 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:46.904798 [ 5110 ] {e403b871-c167-4479-a92f-5da387dcab15} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function countSubstrings: In scope SELECT countSubstrings([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 367, line 368) (in query: SELECT countSubstrings([], [], []);) 2025.06.13 15:48:46.924527 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function countSubstrings: In scope SELECT countSubstrings([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:46.950972 [ 8101 ] {8c82922e-f67f-4c96-8723-0112d75674d6} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1042, line 1042) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt16(-1) as r FORMAT CSV;) 2025.06.13 15:48:46.960462 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:47.066140 [ 5110 ] {5dd7340c-8046-4684-832d-d81a65e4bef2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function countSubstringsCaseInsensitive: In scope SELECT countSubstringsCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 368, line 369) (in query: SELECT countSubstringsCaseInsensitive([], [], []);) 2025.06.13 15:48:47.084252 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function countSubstringsCaseInsensitive: In scope SELECT countSubstringsCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:47.219432 [ 5110 ] {1a94996a-d186-4dcc-b2c1-2e8959fa2d6f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function countSubstringsCaseInsensitiveUTF8: In scope SELECT countSubstringsCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 369, line 370) (in query: SELECT countSubstringsCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:48:47.228639 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function countSubstringsCaseInsensitiveUTF8: In scope SELECT countSubstringsCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:47.284369 [ 2860 ] {a6017ca7-1f69-4d93-8db8-6b4975eb27f9} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52792) (comment: 02381_compress_marks_and_primary_key.sql) (query 3, line 6) (in query: create table test_02381(a UInt64, b UInt64) ENGINE = MergeTree order by (a, b) SETTINGS compress_marks = false, compress_primary_key = false, ratio_of_defaults_for_sparse_serialization = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:47.340252 [ 5110 ] {1d3a6f2c-1d20-4bb3-b4e1-42d322136c47} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 370, line 371) (in query: SELECT covarPop([], [], []);) 2025.06.13 15:48:47.347153 [ 2860 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:47.378352 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:47.513099 [ 5110 ] {0211d647-cf34-4308-a21c-00dba0f9409d} executeQuery: Code: 43. DB::Exception: Aggregate function covarPopMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 371, line 372) (in query: SELECT covarPopMatrix([], [], []);) 2025.06.13 15:48:47.521658 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function covarPopMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:47.605568 [ 5110 ] {ac4cfebe-3d44-4348-94e8-095781f4355b} executeQuery: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 372, line 373) (in query: SELECT covarPopStable([], [], []);) 2025.06.13 15:48:47.615449 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:47.687072 [ 5110 ] {c77678d0-81e1-4a41-9c32-5b1543fad72c} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 373, line 374) (in query: SELECT covarSamp([], [], []);) 2025.06.13 15:48:47.700717 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:47.809995 [ 8101 ] {ec8f3d32-f12b-4de2-ae59-bfaf0ff22a54} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1047, line 1047) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) <= N as r FORMAT CSV;) 2025.06.13 15:48:47.815660 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:47.844583 [ 5110 ] {5ff373d0-7fd0-49e8-a452-5e3546435020} executeQuery: Code: 43. DB::Exception: Aggregate function covarSampMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 374, line 375) (in query: SELECT covarSampMatrix([], [], []);) 2025.06.13 15:48:47.871239 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function covarSampMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:48.071738 [ 5110 ] {497d07ce-8054-4b9c-910e-d412d872279f} executeQuery: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 375, line 376) (in query: SELECT covarSampStable([], [], []);) 2025.06.13 15:48:48.103657 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:48.203244 [ 5110 ] {340efbcd-d542-4ed9-9fb9-ea8d7be219bb} executeQuery: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 376, line 377) (in query: SELECT cramersV([], [], []);) 2025.06.13 15:48:48.211218 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:48.312317 [ 5110 ] {044870fc-df50-42ea-8280-f42eee7497aa} executeQuery: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 377, line 378) (in query: SELECT cramersVBiasCorrected([], [], []);) 2025.06.13 15:48:48.343272 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:48.438668 [ 5110 ] {4ececdbe-d19f-4c57-8195-4d63fa237c5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 378, line 379) (in query: SELECT curdate([], [], []);) 2025.06.13 15:48:48.456425 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:48.608046 [ 5110 ] {9251ec75-ed65-45c8-9c59-14d1c621abd2} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 379, line 380) (in query: SELECT currentDatabase([], [], []);) 2025.06.13 15:48:48.623110 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:48.732179 [ 5110 ] {56bc775a-2a48-4df5-b126-2742d38d5183} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 380, line 381) (in query: SELECT currentProfiles([], [], []);) 2025.06.13 15:48:48.750619 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:48.760438 [ 8101 ] {45966686-332c-4010-94cb-ce0e7c4a1c1f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1052, line 1052) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt32(1) as r FORMAT CSV;) 2025.06.13 15:48:48.768806 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:48.889732 [ 5110 ] {3817c20b-d5b2-42d3-81e1-5297b7b28562} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT currentQueryID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 381, line 382) (in query: SELECT currentQueryID([], [], []);) 2025.06.13 15:48:48.923425 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT currentQueryID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:48.990720 [ 5110 ] {408921ed-7135-4f59-92bd-e2553a5ea083} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 382, line 383) (in query: SELECT currentRoles([], [], []);) 2025.06.13 15:48:49.023901 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:49.188029 [ 5110 ] {93a02c42-ac07-4ea9-9cb8-4f97f5b2d2df} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 383, line 384) (in query: SELECT currentSchemas([], [], []);) 2025.06.13 15:48:49.194416 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:49.243145 [ 5110 ] {89ffed88-f5ac-4b76-9d3a-b8ada62734e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 384, line 385) (in query: SELECT currentUser([], [], []);) 2025.06.13 15:48:49.261680 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:49.368150 [ 5110 ] {a9395ec3-9f5a-4a4c-8bd4-34b82800737d} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 385, line 386) (in query: SELECT current_database([], [], []);) 2025.06.13 15:48:49.376204 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:49.450948 [ 5110 ] {080d7ab9-6676-4fb2-8eac-6790242427ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 386, line 387) (in query: SELECT current_date([], [], []);) 2025.06.13 15:48:49.481293 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:49.623345 [ 5110 ] {d37af4bf-9dd4-4e7e-87c6-0484069efe2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT current_query_id([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 387, line 388) (in query: SELECT current_query_id([], [], []);) 2025.06.13 15:48:49.656869 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT current_query_id([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:49.722997 [ 8101 ] {6e102b50-bdc3-49b6-9b0a-c037c48ca79b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1057, line 1057) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) <= N as r FORMAT CSV;) 2025.06.13 15:48:49.747467 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:49.890151 [ 18510 ] {80f0283a-400a-468b-80fd-0af2450ac169} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52840) (comment: 03249_dynamic_alter_consistency.sql) (query 3, line 6) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree ORDER BY tuple() SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity = 65407, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 7, min_bytes_for_full_part_storage = 189851468, compact_parts_max_bytes_to_buffer = 472640032, compact_parts_max_granules_to_buffer = 244, compact_parts_merge_max_bytes_to_prefetch_part = 2255788, merge_max_block_size = 17846, old_parts_lifetime = 309., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 26722984, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 17086, primary_key_compress_block_size = 13917, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:49.947618 [ 18510 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:49.951580 [ 5110 ] {583bb65b-a047-48e8-b83e-7c838a9c959d} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 388, line 389) (in query: SELECT current_schemas([], [], []);) 2025.06.13 15:48:49.962849 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:50.029278 [ 5110 ] {7b7357f8-468b-4ca7-befe-2a2102fc1390} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 389, line 390) (in query: SELECT current_timestamp([], [], []);) 2025.06.13 15:48:50.043004 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:50.207650 [ 5110 ] {eb3d4e56-261f-45cc-8357-3efdd1f3ebef} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 390, line 391) (in query: SELECT current_user([], [], []);) 2025.06.13 15:48:50.225181 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:50.359572 [ 5110 ] {499cba3a-2d80-46f9-90b2-3752095ec3eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 391, line 392) (in query: SELECT cutFragment([], [], []);) 2025.06.13 15:48:50.377819 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:50.566855 [ 5110 ] {8d17829d-a953-4d34-9acd-0ad44fb9a784} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function cutIPv6, expected FixedString(16): In scope SELECT cutIPv6([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 392, line 393) (in query: SELECT cutIPv6([], [], []);) 2025.06.13 15:48:50.645808 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function cutIPv6, expected FixedString(16): In scope SELECT cutIPv6([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:50.819116 [ 5110 ] {1f4844e6-87c4-40ab-9b3c-e493d0e24d2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 393, line 394) (in query: SELECT cutQueryString([], [], []);) 2025.06.13 15:48:50.855683 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:50.881572 [ 9642 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:50.985547 [ 5110 ] {2d05d564-1d5f-4552-a80c-18ba0ea810e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 394, line 395) (in query: SELECT cutQueryStringAndFragment([], [], []);) 2025.06.13 15:48:50.990419 [ 8101 ] {11d79686-71a6-441e-bf3b-c2491f4bf773} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1062, line 1062) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt32(-1) as r FORMAT CSV;) 2025.06.13 15:48:50.994540 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:51.008347 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:51.108053 [ 5110 ] {455e1662-41d9-408f-833d-bc5673d5ff44} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 395, line 396) (in query: SELECT cutToFirstSignificantSubdomain([], [], []);) 2025.06.13 15:48:51.127514 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:51.219504 [ 5110 ] {8c810ad5-30ef-44da-a228-c0d59c9b7a65} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 396, line 397) (in query: SELECT cutToFirstSignificantSubdomainCustom([], [], []);) 2025.06.13 15:48:51.231027 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:51.376732 [ 5110 ] {83c2ed99-c533-4f91-aa85-1f08e538659a} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 397, line 398) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC([], [], []);) 2025.06.13 15:48:51.393143 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:51.531563 [ 5110 ] {0ca5d579-a6ed-404f-bbcf-4757019c6f77} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 398, line 399) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW([], [], []);) 2025.06.13 15:48:51.538660 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:51.616528 [ 5110 ] {002e23c8-c1c9-4ae7-ae7f-2cb9fb3ce0af} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 399, line 400) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([], [], []);) 2025.06.13 15:48:51.623234 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:51.938267 [ 5110 ] {74881842-c9af-4be9-8bb0-79d9b8f5d677} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 400, line 401) (in query: SELECT cutToFirstSignificantSubdomainRFC([], [], []);) 2025.06.13 15:48:51.971702 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:51.978462 [ 8101 ] {419c1c17-9b2e-4a4a-9843-5374bbcd26e7} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1067, line 1067) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) <= N as r FORMAT CSV;) 2025.06.13 15:48:51.987502 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:52.045476 [ 5110 ] {eb64c5f6-d580-4d5e-be03-7b627353bf7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 401, line 402) (in query: SELECT cutToFirstSignificantSubdomainWithWWW([], [], []);) 2025.06.13 15:48:52.052887 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:52.236777 [ 5110 ] {18d638fd-5aec-48a1-9f19-54c24b2234b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 402, line 403) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC([], [], []);) 2025.06.13 15:48:52.248223 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:52.426895 [ 5110 ] {c323164e-3c56-455b-a0ef-f86d4c7fbd3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 403, line 404) (in query: SELECT cutURLParameter([], [], []);) 2025.06.13 15:48:52.501480 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:52.623753 [ 5110 ] {60cceb0d-8aa8-4bc6-a382-6a34b13aaa74} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 404, line 405) (in query: SELECT cutWWW([], [], []);) 2025.06.13 15:48:52.639420 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:52.722399 [ 5110 ] {eba8fc0b-93ec-46f7-bcc3-df24590a7d8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 405, line 406) (in query: SELECT damerauLevenshteinDistance([], [], []);) 2025.06.13 15:48:52.736129 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:52.788706 [ 5110 ] {f9a9972c-3068-46c4-a4ca-8c074d3e47e8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nothing): In scope SELECT dateDiff([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 406, line 407) (in query: SELECT dateDiff([], [], []);) 2025.06.13 15:48:52.796134 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nothing): In scope SELECT dateDiff([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:52.896040 [ 8101 ] {e1fcb8c7-b5f5-4b0d-8e22-e69e55f583fa} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1072, line 1072) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt64(1) as r FORMAT CSV;) 2025.06.13 15:48:52.915270 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:52.944690 [ 5110 ] {da0d7c17-de24-4fe0-9eca-9696a766d4d2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1 argument of function dateName. Must be string: In scope SELECT dateName([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 407, line 408) (in query: SELECT dateName([], [], []);) 2025.06.13 15:48:52.961700 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1 argument of function dateName. Must be string: In scope SELECT dateName([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:53.077977 [ 5110 ] {7e5e8bc6-2e7c-4e12-b9e0-dcb6151e3b3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 408, line 409) (in query: SELECT dateTime64ToSnowflake([], [], []);) 2025.06.13 15:48:53.127568 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:53.188129 [ 5110 ] {d562dfa2-de21-432e-bc9d-cd8beeb1a546} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTime64ToSnowflakeID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 409, line 410) (in query: SELECT dateTime64ToSnowflakeID([], [], []);) 2025.06.13 15:48:53.210222 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTime64ToSnowflakeID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:53.255445 [ 5110 ] {7c9d5b56-5d78-4064-bc1f-0071499e3480} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 410, line 411) (in query: SELECT dateTimeToSnowflake([], [], []);) 2025.06.13 15:48:53.262195 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:53.394565 [ 5110 ] {eb14bba9-bfad-453f-8c32-f2bdebed593f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTimeToSnowflakeID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 411, line 412) (in query: SELECT dateTimeToSnowflakeID([], [], []);) 2025.06.13 15:48:53.405977 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTimeToSnowflakeID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:53.483632 [ 5110 ] {74e0a2ff-e497-444e-aad6-6f348fa295ef} executeQuery: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT dateTrunc([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 412, line 413) (in query: SELECT dateTrunc([], [], []);) 2025.06.13 15:48:53.504685 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT dateTrunc([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:53.545307 [ 8101 ] {ccdddbd6-f90f-40aa-9fcf-766f8cea2f6e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1077, line 1077) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) <= N as r FORMAT CSV;) 2025.06.13 15:48:53.557508 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:53.571613 [ 18511 ] {639bdf5a-6425-49c6-86de-d245d794aa0d} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57062) (comment: 02420_final_setting.sql) (query 2, line 4) (in query: CREATE TABLE IF NOT EXISTS replacing_mt (`x` String) ENGINE = ReplacingMergeTree ORDER BY x SETTINGS index_granularity = 36761, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 277115201, compact_parts_max_granules_to_buffer = 168, compact_parts_merge_max_bytes_to_prefetch_part = 2460613, merge_max_block_size = 23243, old_parts_lifetime = 67., 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 = 1293991, 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 = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 44083, primary_key_compress_block_size = 69514, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:53.597252 [ 18511 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:48:53.642649 [ 5110 ] {7d0ff9ec-0781-47e6-900e-7bdda2696031} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toStartOfInterval, expected a Date, Date32, DateTime or DateTime64: In scope SELECT date_bin([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 413, line 414) (in query: SELECT date_bin([], [], []);) 2025.06.13 15:48:53.665850 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toStartOfInterval, expected a Date, Date32, DateTime or DateTime64: In scope SELECT date_bin([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:53.722976 [ 5110 ] {e43c4eaf-5ae4-41b4-9f6b-64bcaf208ea7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nothing): In scope SELECT dateDiff([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 414, line 415) (in query: SELECT date_diff([], [], []);) 2025.06.13 15:48:53.725297 [ 3030 ] {} test_3.replicated_truncate2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:48:53.727708 [ 2954 ] {} test_3.replicated_numbers (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:48:53.731143 [ 3035 ] {} test_rov98m53.r_prop_table1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:48:53.731957 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nothing): In scope SELECT dateDiff([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:53.733163 [ 3002 ] {} test_13.replicated_mutations_empty_partitions (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:48:53.734085 [ 2986 ] {} test_13.enum_alter_issue (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:48:53.736072 [ 3043 ] {} test_13.sample_table_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:48:53.747952 [ 2992 ] {} test_13.`02784_async_table_with_dedup` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:48:53.757804 [ 2918 ] {} test_3.mt_compact (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:48:53.759654 [ 2963 ] {} test_13.tp_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:48:53.771025 [ 3048 ] {} test_hftyb7hl.table1 (b91b0a11-11e4-4d17-83b2-53252fb9cf5e): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:53.771548 [ 3079 ] {} test_i0frc2hu.table_for_rename_pk (dea16984-4aa0-486d-9e01-a267b94adf66): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:53.773343 [ 3067 ] {} test_nkpekc8y.keeper_retries_r1 (fc10f32a-6845-4cb3-98aa-7c8b52a73b53): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:53.774893 [ 3073 ] {} test_ww6mlyc5.rename2 (7960be3e-3bcb-4d71-9057-066fb14b373f): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:53.775161 [ 3063 ] {} test_ww6mlyc5.rename1 (3cca5120-2f83-43ca-887e-56a11f3e0b59): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:53.777453 [ 3105 ] {} test_nkpekc8y.keeper_retries_r2 (0e9be03e-71e9-4ec3-a42a-1d0646b818d8): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:53.782386 [ 3085 ] {} test_9.replicated_report (8dd7f9d8-40e1-4585-b3fd-65493e77c255): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:53.821638 [ 5110 ] {c8bb425a-fbb5-4c83-a4c8-dc344449a19f} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 415, line 416) (in query: SELECT decodeHTMLComponent([], [], []);) 2025.06.13 15:48:53.832770 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:53.887641 [ 3006 ] {} test_rov98m53.r_prop_table2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Session expired (fault injected on send). Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x0000000031173f2d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x0000000031173e22 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1781: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000003281b9e0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1294: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281aad2 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1521: Coordination::ZooKeeper::set(String const&, String const&, int, std::function) @ 0x0000000032820d19 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1323: zkutil::ZooKeeper::asyncTrySetNoThrow(String const&, String const&, int) @ 0x000000003275b293 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:708: zkutil::ZooKeeper::setImpl(String const&, String const&, int, Coordination::Stat*) @ 0x000000003275ae75 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:743: zkutil::ZooKeeper::set(String const&, String const&, int, Coordination::Stat*) @ 0x000000003275b492 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3768: DB::StorageReplicatedMergeTree::cloneReplicaIfNeeded(std::shared_ptr) @ 0x00000000306327ae 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:194: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x0000000031143c57 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:160: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x0000000031141525 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:86: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x00000000311406e1 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:53.920143 [ 5110 ] {27925580-f452-4a75-b646-5bcf17599a05} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 416, line 417) (in query: SELECT decodeURLComponent([], [], []);) 2025.06.13 15:48:53.940378 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:53.989481 [ 2967 ] {} test_rov98m53.r_prop_table2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.06.13 15:48:54.058603 [ 5110 ] {01b754e1-44c2-4b8c-8338-102d96cfa0ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 417, line 418) (in query: SELECT decodeURLFormComponent([], [], []);) 2025.06.13 15:48:54.071333 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:54.178008 [ 5110 ] {6d820b03-44a3-423f-83e5-637ac1b02b64} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 418, line 419) (in query: SELECT decodeXMLComponent([], [], []);) 2025.06.13 15:48:54.196504 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:54.197168 [ 18510 ] {6f9b6fcc-e3bc-4f5b-a64a-7635ccc749e8} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_rov98m53.r_prop_table1 (c9b29f0c-79dc-4e58-995e-cd151897d715)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52938) (comment: 01493_alter_remove_properties_zookeeper.sql) (query 8, line 33) (in query: INSERT INTO r_prop_table1 (column_codec, column_comment, column_ttl) VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:48:54.208950 [ 8101 ] {72bb8286-cc5e-4425-a850-6e086c740ac7} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1082, line 1082) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt64(-1) as r FORMAT CSV;) 2025.06.13 15:48:54.216721 [ 18510 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_rov98m53.r_prop_table1 (c9b29f0c-79dc-4e58-995e-cd151897d715)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:48:54.223100 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:54.287695 [ 5110 ] {ea2a4cdc-c72c-4652-9bb1-25ac6b1a8af0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'decrypt'. Expected: decryption mode string, got: Array(Nothing): In scope SELECT decrypt([], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 419, line 420) (in query: SELECT decrypt([], '[HIDDEN]')) 2025.06.13 15:48:54.297631 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'decrypt'. Expected: decryption mode string, got: Array(Nothing): In scope SELECT decrypt([], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:54.390698 [ 5110 ] {8c9111c5-26bc-4e16-97a0-8005b6a7c350} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 420, line 421) (in query: SELECT defaultProfiles([], [], []);) 2025.06.13 15:48:54.407900 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:54.526412 [ 5110 ] {8859d21f-b1c7-4c85-8ad3-ebcd32fa3952} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 421, line 422) (in query: SELECT defaultRoles([], [], []);) 2025.06.13 15:48:54.539590 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:54.730167 [ 5110 ] {363bddb1-bb6b-4e5e-a28d-8151c0699233} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 422, line 423) (in query: SELECT defaultValueOfArgumentType([], [], []);) 2025.06.13 15:48:54.742489 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:54.865402 [ 5110 ] {8f88fb6b-cdac-42c7-980d-fa1c06c49c2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 423, line 424) (in query: SELECT defaultValueOfTypeName([], [], []);) 2025.06.13 15:48:54.879355 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:54.967056 [ 5110 ] {efd219dc-e9a7-402a-9798-a0bc9c7889fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 424, line 425) (in query: SELECT degrees([], [], []);) 2025.06.13 15:48:55.034803 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:55.065084 [ 8101 ] {5d8bed85-4aa9-4177-9ffb-aaf6e8ba598c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1087, line 1087) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) <= N as r FORMAT CSV;) 2025.06.13 15:48:55.097867 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:55.155690 [ 5110 ] {2952f69f-be44-4324-bfdd-8c0c69e5853f} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 425, line 426) (in query: SELECT deltaSum([], [], []);) 2025.06.13 15:48:55.172919 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:55.278222 [ 5110 ] {ef4a065b-270d-4012-ad1a-35c0862aa677} executeQuery: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 426, line 427) (in query: SELECT deltaSumTimestamp([], [], []);) 2025.06.13 15:48:55.305092 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:55.366538 [ 18510 ] {50043456-918d-485e-b77b-19ac7b87b02c} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_rov98m53.r_prop_table1 (c9b29f0c-79dc-4e58-995e-cd151897d715)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38496) (comment: 01493_alter_remove_properties_zookeeper.sql) (in query: DROP DATABASE IF EXISTS test_rov98m53 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:48:55.381073 [ 18510 ] {50043456-918d-485e-b77b-19ac7b87b02c} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_rov98m53.r_prop_table1 (c9b29f0c-79dc-4e58-995e-cd151897d715)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:55.411671 [ 5110 ] {27b37270-9954-412c-a8bc-985aee2b0fa8} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 427, line 428) (in query: SELECT demangle([], [], []);) 2025.06.13 15:48:55.422022 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:55.754404 [ 5110 ] {8d32669a-e0b9-45e8-95e1-18032e6d4e03} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 428, line 429) (in query: SELECT denseRank([], [], []);) 2025.06.13 15:48:55.764857 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:48:55.963518 [ 5110 ] {11b73435-f707-4789-97c3-a2e1493c1199} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 429, line 430) (in query: SELECT dense_rank([], [], []);) 2025.06.13 15:48:55.976683 [ 8101 ] {2b0ea6d4-7833-4b69-9e8c-a6358831d86d} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1092, line 1092) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt8(1) as r FORMAT CSV;) 2025.06.13 15:48:55.979044 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:48:55.982394 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:56.039645 [ 5110 ] {2684255c-c7be-4415-a25d-e9098e30e4cc} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 430, line 431) (in query: SELECT detectCharset([], [], []);) 2025.06.13 15:48:56.077961 [ 5110 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:48:56.245405 [ 5110 ] {66d3f6d2-2a95-4c25-b6f2-13888dc11779} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 431, line 432) (in query: SELECT detectLanguage([], [], []);) 2025.06.13 15:48:56.257139 [ 5110 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:48:56.446639 [ 5110 ] {fe3a0237-b4bc-455b-9772-56a8c25077ca} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 432, line 433) (in query: SELECT detectLanguageMixed([], [], []);) 2025.06.13 15:48:56.452989 [ 5110 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:48:56.540803 [ 5110 ] {995f6327-eb9e-43d8-befe-9351bfbca4e2} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 433, line 434) (in query: SELECT detectLanguageUnknown([], [], []);) 2025.06.13 15:48:56.552111 [ 5110 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:48:56.652564 [ 5110 ] {1d44456d-363d-4295-a8dc-384dbb256334} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 434, line 435) (in query: SELECT detectProgrammingLanguage([], [], []);) 2025.06.13 15:48:56.684861 [ 5110 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:48:56.800961 [ 8101 ] {9fe8d7bf-9483-4f23-8bfc-0f675163d651} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1097, line 1097) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) > N as r FORMAT CSV;) 2025.06.13 15:48:56.810558 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:56.867313 [ 5110 ] {8fde761c-8af3-483c-adb0-44060a2ffb4b} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 435, line 436) (in query: SELECT detectTonality([], [], []);) 2025.06.13 15:48:56.893658 [ 5110 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:48:56.968509 [ 9642 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:57.019588 [ 5110 ] {c631dd7a-d6fc-4ba6-be7c-1b7c395b738b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 436, line 437) (in query: SELECT dictGet([], [], []);) 2025.06.13 15:48:57.047536 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:57.184451 [ 5110 ] {dad7a090-9127-4364-8a17-688ee7d54b06} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 437, line 438) (in query: SELECT dictGetAll([], [], []);) 2025.06.13 15:48:57.194091 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:57.351662 [ 5110 ] {4a0c5ee8-4955-4361-a5f6-441e234b2710} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 438, line 439) (in query: SELECT dictGetChildren([], [], []);) 2025.06.13 15:48:57.364995 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:57.429739 [ 5110 ] {51abcbfc-d52a-42b3-8734-7e34b436ac92} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetDate([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 439, line 440) (in query: SELECT dictGetDate([], [], []);) 2025.06.13 15:48:57.440108 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetDate([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:57.529253 [ 5110 ] {5dc494d8-1b25-4b23-879e-f7d2a33b0c2e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetDateOrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 440, line 441) (in query: SELECT dictGetDateOrDefault([], [], []);) 2025.06.13 15:48:57.542522 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetDateOrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:57.650362 [ 5110 ] {999687c4-3640-462c-aace-819a8ff20fe2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetDateTime([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 441, line 442) (in query: SELECT dictGetDateTime([], [], []);) 2025.06.13 15:48:57.670251 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetDateTime([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:57.713688 [ 10757 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=908, jobs=897). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b3756 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:57.742644 [ 8101 ] {83e9aab8-932c-4d0b-b362-2981188e4841} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1102, line 1102) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt8(-1) as r FORMAT CSV;) 2025.06.13 15:48:57.751996 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:57.839173 [ 34716 ] {} DDLWorker(test_wrnj8dwa): Error on initialization of test_wrnj8dwa: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_wrnj8dwa' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=908, jobs=897). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b3756 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)). (ASYNC_LOAD_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Common/AsyncLoader.cpp:447: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000023e83361 6. ./src/Common/AsyncLoader.h:548: DB::waitLoad(unsigned long, std::shared_ptr const&, bool) @ 0x000000002c6fbe34 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:787: DB::DatabaseReplicated::waitDatabaseStarted() const @ 0x000000002c7641d7 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1183: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x000000002c77686c 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x000000002c7aa17d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x000000002c7a6403 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000002d5b3e9b 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b36ee 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:48:57.840497 [ 5110 ] {693f5afa-5799-42b5-95a0-1443187ac63e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetDateTimeOrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 442, line 443) (in query: SELECT dictGetDateTimeOrDefault([], [], []);) 2025.06.13 15:48:57.848549 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetDateTimeOrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:57.934172 [ 5110 ] {d10a5adb-69cb-438c-844e-e33e38c148f7} executeQuery: Code: 43. DB::Exception: Illegal type of first argument of function dictGetDescendants. Expected const String. Actual type Array(Nothing): In scope SELECT dictGetDescendants([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 443, line 444) (in query: SELECT dictGetDescendants([], [], []);) 2025.06.13 15:48:57.948729 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type of first argument of function dictGetDescendants. Expected const String. Actual type Array(Nothing): In scope SELECT dictGetDescendants([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:58.026286 [ 5110 ] {4ada772f-ee7c-4793-92e8-fbe06bfe30da} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetFloat32([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 444, line 445) (in query: SELECT dictGetFloat32([], [], []);) 2025.06.13 15:48:58.044054 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetFloat32([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:58.203445 [ 5110 ] {a55f0662-ba57-4429-bf98-2869ecd08d8f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetFloat32OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 445, line 446) (in query: SELECT dictGetFloat32OrDefault([], [], []);) 2025.06.13 15:48:58.234927 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetFloat32OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:58.368424 [ 5110 ] {ff2ef301-b3c4-47fe-940a-1b560bd4fff2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetFloat64([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 446, line 447) (in query: SELECT dictGetFloat64([], [], []);) 2025.06.13 15:48:58.382847 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetFloat64([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:58.508789 [ 5110 ] {d0df816b-20e5-4ef1-9d12-b943e96f599c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetFloat64OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 447, line 448) (in query: SELECT dictGetFloat64OrDefault([], [], []);) 2025.06.13 15:48:58.514923 [ 8101 ] {a42f8448-4b5d-4cca-b383-3e772e0d93b4} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1107, line 1107) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) > N as r FORMAT CSV;) 2025.06.13 15:48:58.515618 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetFloat64OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:58.521963 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:58.608374 [ 5110 ] {b1dd1806-8005-45b3-a4f6-1d8cb0912ee3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 448, line 449) (in query: SELECT dictGetHierarchy([], [], []);) 2025.06.13 15:48:58.653423 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:48:58.729371 [ 5110 ] {55373941-d76e-4e9e-8389-4ad4aa24f632} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetIPv4([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 449, line 450) (in query: SELECT dictGetIPv4([], [], []);) 2025.06.13 15:48:58.742332 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetIPv4([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:58.833544 [ 5110 ] {0326fb6f-265b-4b1a-8176-13e31ee5905d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetIPv4OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 450, line 451) (in query: SELECT dictGetIPv4OrDefault([], [], []);) 2025.06.13 15:48:58.841122 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetIPv4OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:58.923732 [ 5110 ] {04774383-7cb5-45d3-956e-0da8aef60e9b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetIPv6([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 451, line 452) (in query: SELECT dictGetIPv6([], [], []);) 2025.06.13 15:48:58.931433 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetIPv6([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:59.003729 [ 4166 ] {fd6219aa-5d3b-4cbb-9cdf-c06b48947436} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE x != 0 WHERE arr. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57178) (comment: 01674_where_prewhere_array_crash.sql) (query 3, line 3) (in query: select x from tab array join arr prewhere x != 0 where arr;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09140f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cc964cd 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cc96058 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0bf 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:48:59.023544 [ 4166 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE x != 0 WHERE arr. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09140f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cc964cd 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cc96058 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0bf 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:48:59.039746 [ 5110 ] {c529d560-2006-4b05-b8da-11b4a85ec988} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetIPv6OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 452, line 453) (in query: SELECT dictGetIPv6OrDefault([], [], []);) 2025.06.13 15:48:59.075485 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetIPv6OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:59.236259 [ 5110 ] {55cabb96-ca3d-4c70-b27a-df29cbba5534} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt16([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 453, line 454) (in query: SELECT dictGetInt16([], [], []);) 2025.06.13 15:48:59.270841 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt16([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:59.274706 [ 4166 ] {7dd74e63-9734-4b3f-9654-9f1620152047} executeQuery: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE arr WHERE x != 0. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57178) (comment: 01674_where_prewhere_array_crash.sql) (query 4, line 4) (in query: select x from tab array join arr prewhere arr where x != 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09140f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cc964cd 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:64: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cc95f9b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0bf 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:48:59.280765 [ 4166 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE arr WHERE x != 0. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002c09140f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000002cc964cd 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:64: DB::validateFilters(std::shared_ptr const&) @ 0x000000002cc95f9b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5758: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0bf 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:48:59.371017 [ 8101 ] {be147c73-cad9-4f6c-96ee-81974cef9f02} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1112, line 1112) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt16(1) as r FORMAT CSV;) 2025.06.13 15:48:59.374714 [ 5110 ] {e309a5d0-751b-4049-b1bc-1d4488b3e6c0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt16OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 454, line 455) (in query: SELECT dictGetInt16OrDefault([], [], []);) 2025.06.13 15:48:59.377148 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:59.384830 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt16OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:59.566206 [ 5110 ] {859c3ec7-420e-49db-aff9-859846b5d237} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt32([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 455, line 456) (in query: SELECT dictGetInt32([], [], []);) 2025.06.13 15:48:59.578513 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt32([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:59.726704 [ 5110 ] {910d5126-b165-48f9-b84a-81946a753140} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt32OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 456, line 457) (in query: SELECT dictGetInt32OrDefault([], [], []);) 2025.06.13 15:48:59.739435 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt32OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:59.817659 [ 5110 ] {067a9c7f-1c77-4a9d-8d57-ac2d3bf4aaf9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt64([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 457, line 458) (in query: SELECT dictGetInt64([], [], []);) 2025.06.13 15:48:59.832928 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt64([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:48:59.942405 [ 5110 ] {bd707059-4b2e-4e6f-b57d-af77cd4fc9ed} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt64OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 458, line 459) (in query: SELECT dictGetInt64OrDefault([], [], []);) 2025.06.13 15:48:59.953074 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt64OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:00.138581 [ 5110 ] {db849d9d-0340-4b3e-bcfb-e6ba1db2cd7c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 459, line 460) (in query: SELECT dictGetInt8([], [], []);) 2025.06.13 15:49:00.176561 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:00.312717 [ 8101 ] {1283bba1-febe-4bfc-825d-c5b6cfef9ad9} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1117, line 1117) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) > N as r FORMAT CSV;) 2025.06.13 15:49:00.330915 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:00.405839 [ 5110 ] {a67d9bd3-b0a0-4c10-87d2-55c65411e294} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt8OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 460, line 461) (in query: SELECT dictGetInt8OrDefault([], [], []);) 2025.06.13 15:49:00.435665 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt8OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:00.555991 [ 5110 ] {d5638c15-8064-48a9-98f1-c24ce38f7422} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 461, line 462) (in query: SELECT dictGetOrDefault([], [], []);) 2025.06.13 15:49:00.561925 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:00.683459 [ 5110 ] {5c22af0e-3d1c-449e-aad5-377b8f1f9d77} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 462, line 463) (in query: SELECT dictGetOrNull([], [], []);) 2025.06.13 15:49:00.690773 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:00.763915 [ 5110 ] {550daed0-7eea-4bc8-90f4-e71af6068e62} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetString([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 463, line 464) (in query: SELECT dictGetString([], [], []);) 2025.06.13 15:49:00.776184 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetString([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:00.862257 [ 5110 ] {909630c9-2b86-4114-a5d9-ddc5580c297f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetStringOrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 464, line 465) (in query: SELECT dictGetStringOrDefault([], [], []);) 2025.06.13 15:49:00.875430 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetStringOrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:01.028310 [ 5110 ] {33598a95-bba2-4c53-b441-98707fcb37cc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt16([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 465, line 466) (in query: SELECT dictGetUInt16([], [], []);) 2025.06.13 15:49:01.046197 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt16([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:01.168205 [ 5110 ] {c3ce13c6-dfb1-4941-99cd-45a2ea264833} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt16OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 466, line 467) (in query: SELECT dictGetUInt16OrDefault([], [], []);) 2025.06.13 15:49:01.177999 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt16OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:01.196444 [ 8101 ] {16310e28-c8ce-45d1-9c8b-0e9af70b421c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1122, line 1122) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt16(-1) as r FORMAT CSV;) 2025.06.13 15:49:01.201180 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:01.259361 [ 5110 ] {f5ca918c-3ca2-4475-9fdb-892717a1a20e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt32([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 467, line 468) (in query: SELECT dictGetUInt32([], [], []);) 2025.06.13 15:49:01.267648 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt32([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:01.383340 [ 5110 ] {02bfc458-4a74-4177-abc5-7291618bf7e9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt32OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 468, line 469) (in query: SELECT dictGetUInt32OrDefault([], [], []);) 2025.06.13 15:49:01.416633 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt32OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:01.568391 [ 5110 ] {d4152474-9ef9-425f-a70d-2839adee3479} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt64([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 469, line 470) (in query: SELECT dictGetUInt64([], [], []);) 2025.06.13 15:49:01.575853 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt64([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:01.677906 [ 5110 ] {b8592574-62e6-4d92-bc99-2ed985806cb1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt64OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 470, line 471) (in query: SELECT dictGetUInt64OrDefault([], [], []);) 2025.06.13 15:49:01.695695 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt64OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:01.697537 [ 4166 ] {421aaf7d-1a19-4d8e-9d82-b4711abfa7fe} executeQuery: Code: 184. DB::Exception: Aggregate function sum(marks) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57216) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (query 5, line 9) (in query: SELECT ignore(toFixedString('Lambda as function parameter', 28), toNullable(28), ignore(8)), sum(marks) FROM system.parts WHERE database = currentDatabase() GROUP BY GROUPING SETS ((2)) FORMAT Null settings optimize_injective_functions_in_group_by=1, optimize_group_by_function_keys=1, group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04442f 5. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f4e4 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f275 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f275 8. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000002cc9f757 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc97a50 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:49:01.717175 [ 4166 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function sum(marks) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000001a04442f 5. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f4e4 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f275 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9f275 8. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000002cc9f757 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc97a50 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:49:01.836726 [ 5110 ] {82e59216-548a-46c7-b2ac-8418134fe438} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 471, line 472) (in query: SELECT dictGetUInt8([], [], []);) 2025.06.13 15:49:01.868909 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:01.966817 [ 5110 ] {9f566d92-1361-40e7-8bb4-694043a1dd5d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt8OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 472, line 473) (in query: SELECT dictGetUInt8OrDefault([], [], []);) 2025.06.13 15:49:02.018542 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt8OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:02.092571 [ 8101 ] {c2bc0266-693b-4349-8ed1-911b3163670a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1127, line 1127) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) > N as r FORMAT CSV;) 2025.06.13 15:49:02.128103 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:02.149765 [ 5110 ] {0513c48e-6100-4cc5-997f-a70434c602be} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUUID([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 473, line 474) (in query: SELECT dictGetUUID([], [], []);) 2025.06.13 15:49:02.155824 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUUID([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:02.186424 [ 4166 ] {63f0e56d-fa36-43b6-b30b-99b1f6a8fccf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=908, jobs=896). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57216) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (query 7, line 13) (in query: SELECT tuple(tuple(number)) AS x FROM numbers(10) GROUP BY (number, (toString(x), number)) WITH CUBE SETTINGS group_by_use_nulls = 1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:02.220242 [ 4166 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=908, jobs=896). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:02.318994 [ 5110 ] {472c1acb-1d7a-4270-b21d-ca1b1fc28930} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUUIDOrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 474, line 475) (in query: SELECT dictGetUUIDOrDefault([], [], []);) 2025.06.13 15:49:02.353039 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUUIDOrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:02.554352 [ 5110 ] {1a3cda5c-f39c-427a-91e9-8f0ee538fc98} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictHas, expected a string: In scope SELECT dictHas([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 475, line 476) (in query: SELECT dictHas([], [], []);) 2025.06.13 15:49:02.562870 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictHas, expected a string: In scope SELECT dictHas([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:02.656649 [ 5110 ] {28bd5745-b84c-4d13-9319-d126e714ff40} executeQuery: Code: 43. DB::Exception: Illegal type of first argument of function dictIsIn. Expected String. Actual type Array(Nothing): In scope SELECT dictIsIn([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 476, line 477) (in query: SELECT dictIsIn([], [], []);) 2025.06.13 15:49:02.674563 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type of first argument of function dictIsIn. Expected String. Actual type Array(Nothing): In scope SELECT dictIsIn([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:02.765713 [ 5978 ] {43b824c2-a52b-45a9-9a4c-f7638a1fbb49} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=908, jobs=897). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56248) (comment: 01720_join_implicit_cast.gen.sql) (query 103, line 127) (in query: SELECT any(toTypeName(a)) == 'Int32' AND any(toTypeName(b)) == 'Nullable(Int64)' FROM t_ab1 RIGHT JOIN t_ab2 USING (a, b);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:02.801046 [ 5110 ] {60509875-e3bc-4d46-98d8-f0300c7d7688} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 477, line 478) (in query: SELECT displayName([], [], []);) 2025.06.13 15:49:02.828391 [ 5978 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=908, jobs=897). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:02.854468 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:02.974982 [ 9642 ] {2e3d1463-f86c-4a8b-adbc-0aa88406e2c1} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_wrnj8dwa' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=908, jobs=897). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b3756 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)). (ASYNC_LOAD_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38570) (comment: 00016_totals_having_constants.sql) (in query: CREATE DATABASE IF NOT EXISTS test_wrnj8dwa ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Common/AsyncLoader.cpp:447: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000023e83361 6. ./src/Common/AsyncLoader.h:548: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a666 7. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:49:02.981604 [ 9642 ] {2e3d1463-f86c-4a8b-adbc-0aa88406e2c1} DynamicQueryHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_wrnj8dwa' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=908, jobs=897). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000002d5df673 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000002d5b3756 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:770: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x000000002c795acf 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023e874b0 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000023e850f6 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000023e81cde 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000023e7ffc2 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000023e8090b 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a5a2 9. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)). (ASYNC_LOAD_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Common/AsyncLoader.cpp:447: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x0000000023e83361 6. ./src/Common/AsyncLoader.h:548: DB::waitLoad(std::vector, std::allocator>> const&, bool) @ 0x0000000023e5a666 7. ./src/Common/AsyncLoader.h:596: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54f74 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:03.072316 [ 5110 ] {2f32c77b-c9bf-45b5-807a-fe1afa00ba50} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 478, line 479) (in query: SELECT distanceL1([], [], []);) 2025.06.13 15:49:03.087971 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:03.208383 [ 5110 ] {aca9235b-8386-4dae-85ca-cf77bd973230} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 479, line 480) (in query: SELECT distanceL2([], [], []);) 2025.06.13 15:49:03.226508 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:03.240976 [ 8101 ] {a31c250d-b6eb-4632-8949-646823676093} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1132, line 1132) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt32(1) as r FORMAT CSV;) 2025.06.13 15:49:03.308612 [ 4163 ] {26971f2f-eeda-42f0-b1f1-b825014558d5} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:4c58ba56-af28-4d44-9545-083a6eddf0fd'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52034) (comment: 01114_mysql_database_engine_segfault.sql) (in query: CREATE DATABASE IF NOT EXISTS test_osocl6xn ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:03.315067 [ 4163 ] {26971f2f-eeda-42f0-b1f1-b825014558d5} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:4c58ba56-af28-4d44-9545-083a6eddf0fd'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:03.342894 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:03.380380 [ 5110 ] {a64c4ca0-d8b7-4e37-b0a9-dc1c7696c9d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 480, line 481) (in query: SELECT distanceL2Squared([], [], []);) 2025.06.13 15:49:03.400479 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:03.497303 [ 4166 ] {10dfca3f-31ab-4e97-9cd9-f8361990ed86} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:49a0ecb9-bd99-4736-8bfd-59a65921ba4a'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52040) (comment: 02354_vector_search_legacy_index_compatibility.sql) (in query: CREATE DATABASE IF NOT EXISTS test_1sdj6reg ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:03.521020 [ 9642 ] {2c1f715c-152c-4ea4-9a2e-1f2d757023e7} 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.20286.altinityantalya (altinity build)) (from [::1]:56962) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long, long) @ 0x0000000020b63b3a 6. 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 @ 0x0000000020bc65b0 7. 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 @ 0x0000000020bb2c21 8. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x0000000020b58f8f 9. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020b56b97 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:49:03.528107 [ 4166 ] {10dfca3f-31ab-4e97-9cd9-f8361990ed86} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:49a0ecb9-bd99-4736-8bfd-59a65921ba4a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:03.546045 [ 9642 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long, long) @ 0x0000000020b63b3a 6. 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 @ 0x0000000020bc65b0 7. 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 @ 0x0000000020bb2c21 8. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x0000000020b58f8f 9. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020b56b97 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:49:03.560776 [ 5110 ] {1f6d1eb3-7ca4-419d-8cb1-65c6fe03a302} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 481, line 482) (in query: SELECT distanceLinf([], [], []);) 2025.06.13 15:49:03.594498 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:03.712223 [ 5110 ] {5b2427d2-3998-4352-ae4a-34178b116103} executeQuery: Code: 43. DB::Exception: Arguments of function arrayLpDistance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT distanceLp([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 482, line 483) (in query: SELECT distanceLp([], [], []);) 2025.06.13 15:49:03.728235 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayLpDistance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT distanceLp([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:03.748396 [ 9642 ] {179680ec-d113-4116-9fcd-b033bb5aa19d} 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.20286.altinityantalya (altinity build)) (from [::1]:56962) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long, long) @ 0x0000000020b63b3a 6. 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 @ 0x0000000020bc65b0 7. 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 @ 0x0000000020bb2c21 8. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x0000000020b58f8f 9. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020b56b97 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:49:03.767095 [ 9642 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long, long) @ 0x0000000020b63b3a 6. 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 @ 0x0000000020bc65b0 7. 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 @ 0x0000000020bb2c21 8. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x0000000020b58f8f 9. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020b56b97 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:49:03.786181 [ 3982 ] {e491911f-a08c-44ed-a3c9-0923903a953f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:f4778e25-1aac-4045-bdbe-95b674176920'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52044) (comment: 01030_final_mark_empty_primary_key.sql) (in query: CREATE DATABASE IF NOT EXISTS test_x3006r63 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:03.796486 [ 3982 ] {e491911f-a08c-44ed-a3c9-0923903a953f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:f4778e25-1aac-4045-bdbe-95b674176920'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:03.856496 [ 5110 ] {890bbafd-ec2e-4cbd-9b78-d639ea1574dd} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctDynamicTypes. Expected single argument with type Dynamic, got 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 483, line 484) (in query: SELECT distinctDynamicTypes([], [], []);) 2025.06.13 15:49:03.878734 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctDynamicTypes. Expected single argument with type Dynamic, got 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:03.999747 [ 5110 ] {e7b48583-dcf2-4e51-a414-d60f89b73c54} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPaths. Expected single argument with type JSON, got 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 484, line 485) (in query: SELECT distinctJSONPaths([], [], []);) 2025.06.13 15:49:04.047161 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPaths. Expected single argument with type JSON, got 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:04.092513 [ 3838 ] {d43f8735-36bb-4c9b-8c8d-5a716331e686} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:f26e3a66-7859-470c-9104-5408731be7ad'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52076) (comment: 00673_subquery_prepared_set_performance.sql) (in query: CREATE DATABASE IF NOT EXISTS test_j722qx2w ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:04.097667 [ 3838 ] {d43f8735-36bb-4c9b-8c8d-5a716331e686} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:f26e3a66-7859-470c-9104-5408731be7ad'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:04.265759 [ 5110 ] {2dbe9a24-b232-4c04-8853-94b759506b8d} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPathsAndTypes. Expected single argument with type JSON, got 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 485, line 486) (in query: SELECT distinctJSONPathsAndTypes([], [], []);) 2025.06.13 15:49:04.287881 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPathsAndTypes. Expected single argument with type JSON, got 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:04.324777 [ 34312 ] {8974fe4c-4a57-4fd0-96b4-5a09c93aef9d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:49f6b309-bb46-4a02-a45d-c17ace1a52dd'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52100) (comment: 02681_group_array_too_large_size.sql) (in query: CREATE DATABASE IF NOT EXISTS test_tdywopmn ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:04.339491 [ 34312 ] {8974fe4c-4a57-4fd0-96b4-5a09c93aef9d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:49f6b309-bb46-4a02-a45d-c17ace1a52dd'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:04.415476 [ 8101 ] {376a5a75-be2a-4f89-b79b-24361ce3c026} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1137, line 1137) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) > N as r FORMAT CSV;) 2025.06.13 15:49:04.431406 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:04.450460 [ 5110 ] {ff044da2-747e-4de9-91ea-9d4eb49bc7be} executeQuery: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 486, line 487) (in query: SELECT divide([], [], []);) 2025.06.13 15:49:04.482414 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:04.528810 [ 3838 ] {1dc59cf9-2138-45f8-bf6e-9467cc6564d2} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:6fb7dc8c-8d9a-4f28-8539-db0753f73222'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52116) (comment: 01518_nullable_aggregate_states2.sql) (in query: CREATE DATABASE IF NOT EXISTS test_tslx1c0c ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:04.541757 [ 3838 ] {1dc59cf9-2138-45f8-bf6e-9467cc6564d2} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:6fb7dc8c-8d9a-4f28-8539-db0753f73222'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:04.612330 [ 5110 ] {321de1b1-c3c7-4dac-bdde-3922ef15564b} executeQuery: Code: 43. DB::Exception: Arguments for divideDecimal function must be Decimal: In scope SELECT divideDecimal([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 487, line 488) (in query: SELECT divideDecimal([], [], []);) 2025.06.13 15:49:04.629444 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Arguments for divideDecimal function must be Decimal: In scope SELECT divideDecimal([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:04.816879 [ 5110 ] {5671d6f7-e434-4165-80ca-72ce3e5a3719} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 488, line 489) (in query: SELECT domain([], [], []);) 2025.06.13 15:49:04.835007 [ 34302 ] {8768556a-cc01-4ade-a0f8-344edab8a597} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:8a90f8fa-9b35-4afa-9d3d-ca074893646d'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52126) (comment: 01952_optimize_distributed_group_by_sharding_key.sql) (in query: CREATE DATABASE IF NOT EXISTS test_i1q90s1d ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:04.840063 [ 34302 ] {8768556a-cc01-4ade-a0f8-344edab8a597} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:8a90f8fa-9b35-4afa-9d3d-ca074893646d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:04.856639 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:05.012208 [ 5110 ] {2d0436f2-8c65-4367-9d4e-2bda47d0585c} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 489, line 490) (in query: SELECT domainRFC([], [], []);) 2025.06.13 15:49:05.040472 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:05.183108 [ 5112 ] {b69ed21c-fbd5-4ed8-9bcc-8ae9ad8dca27} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:a5acbede-47cb-4393-925e-ac035efbb80d'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52142) (comment: 02725_memory-for-merges.sql) (in query: CREATE DATABASE IF NOT EXISTS test_viii640k ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:05.188238 [ 5112 ] {b69ed21c-fbd5-4ed8-9bcc-8ae9ad8dca27} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:a5acbede-47cb-4393-925e-ac035efbb80d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:05.211766 [ 3838 ] {a1a1f7f7-8bef-4367-b84f-653a99555a24} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57030) (comment: 02579_fill_empty_chunk.sql) (query 2, line 4) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:49:05.211827 [ 5110 ] {2b73cacb-8477-4660-b206-a345e300fb0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 490, line 491) (in query: SELECT domainWithoutWWW([], [], []);) 2025.06.13 15:49:05.219564 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:05.243944 [ 3838 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:49:05.352829 [ 5110 ] {dc7af26e-b7a3-462f-9343-2233b314b6a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 491, line 492) (in query: SELECT domainWithoutWWWRFC([], [], []);) 2025.06.13 15:49:05.376071 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:05.420191 [ 6219 ] {0af8e759-724c-4fa5-82ae-b9db2f570b1a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:9bd0fc15-2f4e-419e-9733-773df7af6378'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52144) (comment: 00258_materializing_tuples.sql) (in query: CREATE DATABASE IF NOT EXISTS test_1i57e2td ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:05.424494 [ 6219 ] {0af8e759-724c-4fa5-82ae-b9db2f570b1a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:9bd0fc15-2f4e-419e-9733-773df7af6378'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:05.466214 [ 5110 ] {2203bee2-af91-438e-b2d7-ce341717453f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 492, line 493) (in query: SELECT dotProduct([], [], []);) 2025.06.13 15:49:05.486322 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:05.594228 [ 5163 ] {7852b281-3172-4e98-9524-cc84af1bd2ab} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:a0fbd1ac-7f91-4d4e-a39f-bd29cac798a6'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52164) (comment: 03257_reverse_sorting_key_simple.sql) (in query: CREATE DATABASE IF NOT EXISTS test_8dm6ckum ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:05.597174 [ 5163 ] {7852b281-3172-4e98-9524-cc84af1bd2ab} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:a0fbd1ac-7f91-4d4e-a39f-bd29cac798a6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:05.599379 [ 5110 ] {a66f83b4-3540-403a-beeb-cf488a519338} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 493, line 494) (in query: SELECT dumpColumnStructure([], [], []);) 2025.06.13 15:49:05.610935 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:05.634033 [ 8101 ] {ff52a42f-0edf-4363-a99e-92b1d142c4b3} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1142, line 1142) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt32(-1) as r FORMAT CSV;) 2025.06.13 15:49:05.657675 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:05.732761 [ 5110 ] {fef04ee8-8847-42d6-a31d-f2f0d4da01aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 494, line 495) (in query: SELECT dynamicElement([], [], []);) 2025.06.13 15:49:05.811186 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:05.819642 [ 5112 ] {eed76645-3703-4f73-892a-ae03bddabaf3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:021eba55-c883-4749-9e81-0ee0f12bd4a4'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52182) (comment: 01083_cross_to_inner_with_in_bug.sql) (in query: CREATE DATABASE IF NOT EXISTS test_sik7xe2i ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:05.829119 [ 5112 ] {eed76645-3703-4f73-892a-ae03bddabaf3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:021eba55-c883-4749-9e81-0ee0f12bd4a4'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:05.964084 [ 5110 ] {ff2f800b-3991-4da2-8ca5-6924cfad4a76} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 495, line 496) (in query: SELECT dynamicType([], [], []);) 2025.06.13 15:49:05.976636 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:06.090663 [ 6219 ] {18d3fb35-3445-44c1-b9cb-6002f7c78e71} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:72c4f273-972f-4f2d-a801-7e1e1fe7496a'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52192) (comment: 01709_inactive_parts_to_throw_insert.sql) (in query: CREATE DATABASE IF NOT EXISTS test_d0uwlyzv ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:06.094692 [ 6219 ] {18d3fb35-3445-44c1-b9cb-6002f7c78e71} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:72c4f273-972f-4f2d-a801-7e1e1fe7496a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:06.188385 [ 5110 ] {9c324044-9b3b-4304-b04e-a1963e5f4338} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 496, line 497) (in query: SELECT e([], [], []);) 2025.06.13 15:49:06.218539 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:06.418509 [ 34302 ] {e615aef0-2be2-490d-bfe3-5e5afdde8d20} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:26888b9e-6857-4552-805c-84b73d65feb4'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52196) (comment: 02535_json_bson_each_row_curl.sh) (in query: CREATE DATABASE IF NOT EXISTS test_oxscdzfx ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:06.426087 [ 34302 ] {e615aef0-2be2-490d-bfe3-5e5afdde8d20} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:26888b9e-6857-4552-805c-84b73d65feb4'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:06.444997 [ 5110 ] {18ea35fc-8e02-464e-b922-dfa53a956eb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 497, line 498) (in query: SELECT editDistance([], [], []);) 2025.06.13 15:49:06.454166 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:06.596265 [ 5110 ] {502321f4-ffcc-40b5-a663-e1bf0d176b20} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 498, line 499) (in query: SELECT editDistanceUTF8([], [], []);) 2025.06.13 15:49:06.605576 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:06.682447 [ 5112 ] {90a9285d-80df-428d-9e33-79a3510b0762} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:da7b35fa-ba54-4a06-9c22-eeeb0fee1e06'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52208) (comment: 00957_format_with_clashed_aliases.sh) (in query: CREATE DATABASE IF NOT EXISTS test_1whjtbk0 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:06.687116 [ 5112 ] {90a9285d-80df-428d-9e33-79a3510b0762} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:da7b35fa-ba54-4a06-9c22-eeeb0fee1e06'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:06.775893 [ 5110 ] {238692fc-3a19-41a5-8c74-6a8e54142e29} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 499, line 500) (in query: SELECT empty([], [], []);) 2025.06.13 15:49:06.793240 [ 8101 ] {98a14d74-c748-4014-82de-1816d2b9bc2c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1147, line 1147) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) > N as r FORMAT CSV;) 2025.06.13 15:49:06.805807 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:06.814617 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:06.980941 [ 34322 ] {3e29d2d1-8965-4603-8336-3ef25d1875fe} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:a576aedf-b9a7-4ce3-96c8-ba8d79da8050'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52214) (comment: 01293_pretty_max_value_width.sql) (in query: CREATE DATABASE IF NOT EXISTS test_9sxizitc ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:06.981790 [ 5110 ] {af5ffa6b-e7bc-4cdf-9783-9aad0f4250bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 500, line 501) (in query: SELECT emptyArrayDate([], [], []);) 2025.06.13 15:49:06.989013 [ 34322 ] {3e29d2d1-8965-4603-8336-3ef25d1875fe} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:a576aedf-b9a7-4ce3-96c8-ba8d79da8050'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:07.074816 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:07.183452 [ 4172 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:07.202759 [ 5110 ] {6ab69d49-4259-4414-a882-c607876f8925} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 501, line 502) (in query: SELECT emptyArrayDateTime([], [], []);) 2025.06.13 15:49:07.217349 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:07.275839 [ 34347 ] {ce82c390-193b-4fbe-9ea9-d94e35ec26d8} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:47b1d6aa-da20-4268-bb64-4b0dba406f40'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52232) (comment: 02908_filesystem_cache_as_collection.sql) (in query: CREATE DATABASE IF NOT EXISTS test_pgfvpgz0 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:07.301046 [ 34347 ] {ce82c390-193b-4fbe-9ea9-d94e35ec26d8} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:47b1d6aa-da20-4268-bb64-4b0dba406f40'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:07.429191 [ 5110 ] {065ef14d-3bb6-4032-9318-282a51ea4793} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 502, line 503) (in query: SELECT emptyArrayFloat32([], [], []);) 2025.06.13 15:49:07.439643 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:07.683375 [ 5110 ] {51157035-5061-459c-bd15-48a8965923b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 503, line 504) (in query: SELECT emptyArrayFloat64([], [], []);) 2025.06.13 15:49:07.707146 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:07.749448 [ 34322 ] {c8ad8298-30de-4d3c-899b-fbb2d3dd7974} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:3f14b073-c00d-4053-8c3d-b606a0b3ae0a'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52254) (comment: 02421_record_errors_row_by_input_format.sh) (in query: CREATE DATABASE IF NOT EXISTS test_en2kcfs5 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:07.766595 [ 34322 ] {c8ad8298-30de-4d3c-899b-fbb2d3dd7974} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:3f14b073-c00d-4053-8c3d-b606a0b3ae0a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:07.869862 [ 5110 ] {7e22be54-0a28-41b0-b3b0-dfd4a577e861} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 504, line 505) (in query: SELECT emptyArrayInt16([], [], []);) 2025.06.13 15:49:07.888971 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:07.980862 [ 6193 ] {24bbb479-5825-4f5d-abb3-dd23120cf218} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:0f04287f-ae91-4c2d-8597-5e4c09d8b16e'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52262) (comment: 00164_quantileBfloat16.sql) (in query: CREATE DATABASE IF NOT EXISTS test_8ashox2t ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:08.000784 [ 6193 ] {24bbb479-5825-4f5d-abb3-dd23120cf218} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:0f04287f-ae91-4c2d-8597-5e4c09d8b16e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:08.052177 [ 5110 ] {bcaa26b2-d8ed-44b8-bf6f-c97c84ccdf1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 505, line 506) (in query: SELECT emptyArrayInt32([], [], []);) 2025.06.13 15:49:08.060397 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:08.099628 [ 8101 ] {538e4d38-fde1-41cb-8abd-ebeaf6fc04cb} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1152, line 1152) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt64(1) as r FORMAT CSV;) 2025.06.13 15:49:08.113354 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:08.205429 [ 5110 ] {d00d22a1-4355-4c46-9eda-4221becc209b} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 506, line 507) (in query: SELECT emptyArrayInt64([], [], []);) 2025.06.13 15:49:08.222698 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:08.244143 [ 34347 ] {b450f810-a6ab-4244-97e8-bd5a026293e0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:9d340d51-ef82-467c-af19-f68166e989c6'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52266) (comment: 02566_ipv4_ipv6_binary_formats.sh) (in query: CREATE DATABASE IF NOT EXISTS test_u0oa32ag ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:08.257346 [ 34347 ] {b450f810-a6ab-4244-97e8-bd5a026293e0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:9d340d51-ef82-467c-af19-f68166e989c6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:08.399731 [ 5110 ] {f97209b1-194b-40fa-8d23-cbac1d2a96a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 507, line 508) (in query: SELECT emptyArrayInt8([], [], []);) 2025.06.13 15:49:08.435933 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:08.535006 [ 34301 ] {de3f8c8a-2338-4f9c-abbf-9f5666c8928c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:e2a5188b-ab2e-4999-a5a8-ce9150148251'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52282) (comment: 02931_max_num_to_warn.sql) (in query: CREATE DATABASE IF NOT EXISTS test_wfrde4rf ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:08.541197 [ 34301 ] {de3f8c8a-2338-4f9c-abbf-9f5666c8928c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:e2a5188b-ab2e-4999-a5a8-ce9150148251'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:08.552494 [ 3821 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:49:08.554079 [ 3821 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:49:08.605925 [ 5110 ] {75696d91-2fb7-4622-9e50-d2f8904c1a89} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 508, line 509) (in query: SELECT emptyArrayString([], [], []);) 2025.06.13 15:49:08.628102 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:08.787204 [ 5163 ] {adce0a7b-02dd-46e9-98b8-eea13e2a84e1} executeQuery: Code: 210. DB::Exception: Connection reset by peer, while writing to socket (127.0.0.1:35724 -> 127.0.0.2:9000): While executing Remote. (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57084) (comment: 03316_analyzer_unique_table_aliases_dist.sql) (query 2, line 3) (in query: SELECT sum(number GLOBAL IN ( SELECT number AS n FROM numbers(5) WHERE number GLOBAL IN ( SELECT * FROM numbers(3) ) ) AS res), sum(number * res) FROM remote('127.0.0.2', numbers(10));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Client/Connection.cpp:986: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003148677f 7. ./build_docker/./src/Client/Connection.cpp:1174: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x000000003148a88d 8. ./build_docker/./src/Client/HedgedConnections.cpp:134: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&)::$_0::operator()(DB::HedgedConnections::ReplicaState&) const @ 0x00000000314cab1d 9. ./build_docker/./src/Client/HedgedConnections.cpp:140: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x00000000314ca4de 10. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:938: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002c3b5355 11. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:447: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002c3b30dd 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3ea61f 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 14. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 16. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:49:08.795873 [ 18602 ] {99c85945-eec2-4347-bee5-be6c60f9a214} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:bd5bd567-d135-4457-a865-b03c7e664b55'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52304) (comment: 01475_read_subcolumns.sql) (in query: CREATE DATABASE IF NOT EXISTS test_smu3nb27 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:08.812407 [ 18602 ] {99c85945-eec2-4347-bee5-be6c60f9a214} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:bd5bd567-d135-4457-a865-b03c7e664b55'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:08.825959 [ 5163 ] {} TCPHandler: Code: 210. DB::Exception: Connection reset by peer, while writing to socket (127.0.0.1:35724 -> 127.0.0.2:9000): While executing Remote. (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Client/Connection.cpp:986: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003148677f 7. ./build_docker/./src/Client/Connection.cpp:1174: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x000000003148a88d 8. ./build_docker/./src/Client/HedgedConnections.cpp:134: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&)::$_0::operator()(DB::HedgedConnections::ReplicaState&) const @ 0x00000000314cab1d 9. ./build_docker/./src/Client/HedgedConnections.cpp:140: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x00000000314ca4de 10. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:938: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002c3b5355 11. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:447: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002c3b30dd 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3ea61f 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 14. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 16. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:49:08.832382 [ 5110 ] {ed1ec9c6-f6e1-45e8-a0ba-4b1812516bbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 509, line 510) (in query: SELECT emptyArrayToSingle([], [], []);) 2025.06.13 15:49:08.845199 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:09.019932 [ 5110 ] {8171b0f3-2766-4489-abd9-31d9e78982d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 510, line 511) (in query: SELECT emptyArrayUInt16([], [], []);) 2025.06.13 15:49:09.069580 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:09.111817 [ 34301 ] {950e3927-5e8b-4981-892c-f99b73cd0bf6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:06dcfa82-6f32-4570-b40c-b4237e97137c'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52312) (comment: 01281_unsucceeded_insert_select_queries_counter.sql) (in query: CREATE DATABASE IF NOT EXISTS test_u8tasey8 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:09.116687 [ 34301 ] {950e3927-5e8b-4981-892c-f99b73cd0bf6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:06dcfa82-6f32-4570-b40c-b4237e97137c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:09.200118 [ 5110 ] {3ee9ea96-70d7-4ac8-a728-acf04b929345} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 511, line 512) (in query: SELECT emptyArrayUInt32([], [], []);) 2025.06.13 15:49:09.232429 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:09.367277 [ 6193 ] {0fd456a5-5250-4cba-b1dc-6798dc296276} executeQuery: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57136) (comment: 01493_alter_remove_wrong_default.sql) (query 3, line 11) (in query: ALTER TABLE default_table MODIFY COLUMN key REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc894 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:09.375428 [ 6193 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc894 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:09.475518 [ 8101 ] {7f73bdd8-18fd-47bd-86e5-f14b2098dc63} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1157, line 1157) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) > N as r FORMAT CSV;) 2025.06.13 15:49:09.480860 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:09.493095 [ 5110 ] {5538793a-139c-4593-96be-4931b39e22e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 512, line 513) (in query: SELECT emptyArrayUInt64([], [], []);) 2025.06.13 15:49:09.506978 [ 5163 ] {a707d7b2-b1cd-4745-b817-723fac78a397} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:0554493b-a351-4318-9590-a3a7a83479e0'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52318) (comment: 02111_modify_table_comment.sql) (in query: CREATE DATABASE IF NOT EXISTS test_l0ur20mz ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:09.518841 [ 5163 ] {a707d7b2-b1cd-4745-b817-723fac78a397} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:0554493b-a351-4318-9590-a3a7a83479e0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:09.522158 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:09.671125 [ 6193 ] {97aa931f-13c4-4b30-adda-3230f004eb66} executeQuery: Code: 36. DB::Exception: Cannot remove ALIAS from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57136) (comment: 01493_alter_remove_wrong_default.sql) (query 4, line 12) (in query: ALTER TABLE default_table MODIFY COLUMN key REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc986 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:09.700333 [ 6193 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove ALIAS from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc986 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:09.739293 [ 3821 ] {9cf8c669-fdbc-4afe-bf39-2320ba37b57d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:15402edb-3c7a-4a7a-9b65-e061c0b2d4b0'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52338) (comment: 02751_ip_types_aggregate_functions_states.gen.sql) (in query: CREATE DATABASE IF NOT EXISTS test_fyw8sox2 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:09.746636 [ 3821 ] {9cf8c669-fdbc-4afe-bf39-2320ba37b57d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:15402edb-3c7a-4a7a-9b65-e061c0b2d4b0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:09.790655 [ 5110 ] {73e70d39-3ae7-4fac-9d95-39cc05e89c68} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 513, line 514) (in query: SELECT emptyArrayUInt8([], [], []);) 2025.06.13 15:49:09.796756 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:09.955738 [ 34301 ] {859d7932-8924-42cc-8717-a846319e36c3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:69cebdf0-2233-4a6b-a215-176599f23fd7'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52340) (comment: 01275_parallel_mv.gen.sql) (in query: CREATE DATABASE IF NOT EXISTS test_zaxc6sv7 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:09.980892 [ 34301 ] {859d7932-8924-42cc-8717-a846319e36c3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:69cebdf0-2233-4a6b-a215-176599f23fd7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:09.982441 [ 5110 ] {d561d546-31f8-4a79-ae49-75650e4a727e} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 514, line 515) (in query: SELECT enabledProfiles([], [], []);) 2025.06.13 15:49:10.012588 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:10.021038 [ 6193 ] {f7f7212d-a5a5-4037-a9f3-e8135be95fd5} executeQuery: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57136) (comment: 01493_alter_remove_wrong_default.sql) (query 5, line 14) (in query: ALTER TABLE default_table MODIFY COLUMN value1 REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc7a6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:10.036485 [ 6193 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc7a6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:10.104958 [ 6193 ] {b0625114-7e37-46d5-9247-a326d5a3092e} executeQuery: Code: 36. DB::Exception: Cannot remove ALIAS from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57136) (comment: 01493_alter_remove_wrong_default.sql) (query 6, line 15) (in query: ALTER TABLE default_table MODIFY COLUMN value1 REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc986 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:10.114315 [ 6193 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove ALIAS from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc986 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:10.130703 [ 5110 ] {5cbea32f-79ca-4452-8cee-798964705783} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 515, line 516) (in query: SELECT enabledRoles([], [], []);) 2025.06.13 15:49:10.153718 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:10.212569 [ 6193 ] {d8a73a5b-997d-4f39-a802-ac9e21176ea4} executeQuery: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57136) (comment: 01493_alter_remove_wrong_default.sql) (query 7, line 17) (in query: ALTER TABLE default_table MODIFY COLUMN value2 REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc7a6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:10.223164 [ 6193 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc7a6 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:10.249774 [ 34322 ] {adf1371d-36ff-49d3-a657-0f3627ba9759} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:012441db-4005-4a36-a547-ad8fb1d9385f'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52360) (comment: 00094_order_by_array_join_limit.sql) (in query: CREATE DATABASE IF NOT EXISTS test_yozptp7k ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:10.252840 [ 34322 ] {adf1371d-36ff-49d3-a657-0f3627ba9759} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:012441db-4005-4a36-a547-ad8fb1d9385f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:10.268943 [ 5110 ] {d39d0026-5e49-4213-8991-ab1fdef2bce4} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 516, line 517) (in query: SELECT encodeURLComponent([], [], []);) 2025.06.13 15:49:10.297373 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:10.359304 [ 6193 ] {6bd192d7-3ce5-4f98-b49a-3a3c4a14db1b} executeQuery: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57136) (comment: 01493_alter_remove_wrong_default.sql) (query 8, line 18) (in query: ALTER TABLE default_table MODIFY COLUMN value2 REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc894 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:10.367893 [ 6193 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000302cc894 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41255 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:10.470350 [ 8101 ] {09015573-02cb-45b3-bc6a-d39d9f44c41b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1162, line 1162) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt64(-1) as r FORMAT CSV;) 2025.06.13 15:49:10.483008 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:10.529656 [ 34347 ] {e7bc1ac7-7c87-4aa7-92d4-e86ffe15a8b8} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:1142b0ad-98e6-4ab5-b319-6270e4a463f1'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52368) (comment: 02918_fuzzjson_table_function.sql) (in query: CREATE DATABASE IF NOT EXISTS test_vh3qjf9w ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:10.541647 [ 34347 ] {e7bc1ac7-7c87-4aa7-92d4-e86ffe15a8b8} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:1142b0ad-98e6-4ab5-b319-6270e4a463f1'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:10.543852 [ 5110 ] {a0a91a9c-804f-4c22-a973-3900edb0d19c} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 517, line 518) (in query: SELECT encodeURLFormComponent([], [], []);) 2025.06.13 15:49:10.551084 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:10.724768 [ 5110 ] {3fb82b27-a0e4-46ee-8502-a49bd3661404} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 518, line 519) (in query: SELECT encodeXMLComponent([], [], []);) 2025.06.13 15:49:10.741756 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:10.829273 [ 34301 ] {023cf883-5a8a-40c8-bbdd-20f3d5b02357} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:0690d094-ece3-45ab-ac8a-bbc98b7b5fdc'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52376) (comment: 02907_suggestions_readonly_user.expect) (in query: CREATE DATABASE IF NOT EXISTS test_bp2t28pz ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:10.832405 [ 34301 ] {023cf883-5a8a-40c8-bbdd-20f3d5b02357} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:0690d094-ece3-45ab-ac8a-bbc98b7b5fdc'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:10.914144 [ 5110 ] {61928f92-ade4-4a88-97a0-8174ae705f9f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'encrypt'. Expected: encryption mode string, got: Array(Nothing): In scope SELECT encrypt([], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 519, line 520) (in query: SELECT encrypt([], '[HIDDEN]')) 2025.06.13 15:49:10.926818 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'encrypt'. Expected: encryption mode string, got: Array(Nothing): In scope SELECT encrypt([], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:10.971661 [ 5005 ] {d283b660-d090-45bf-8312-d89bb37b5834} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:29fd1d29-c637-401a-af10-e5d108da9290'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52396) (comment: 00040_aggregating_materialized_view.sql) (in query: CREATE DATABASE IF NOT EXISTS test_hzt5fplf ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:10.974791 [ 5005 ] {d283b660-d090-45bf-8312-d89bb37b5834} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:29fd1d29-c637-401a-af10-e5d108da9290'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:10.992142 [ 5110 ] {25ce2964-7eb0-4a5f-8cd2-08038f6b90b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 520, line 521) (in query: SELECT endsWith([], [], []);) 2025.06.13 15:49:11.005028 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:11.105845 [ 5110 ] {dd0ddf8c-b209-462f-a9fd-ae27af79db66} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 521, line 522) (in query: SELECT endsWithUTF8([], [], []);) 2025.06.13 15:49:11.115229 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:11.316032 [ 5005 ] {c42be40a-e688-4c06-a554-d50a38305724} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:078efef7-87a3-4808-bc78-0bb3b53771c6'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52414) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: CREATE DATABASE IF NOT EXISTS test_qnddyzgy ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:11.319625 [ 5005 ] {c42be40a-e688-4c06-a554-d50a38305724} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:078efef7-87a3-4808-bc78-0bb3b53771c6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:11.414961 [ 8101 ] {f443a472-558c-40e0-ab5f-b6d2a8effa2d} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1167, line 1167) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) > N as r FORMAT CSV;) 2025.06.13 15:49:11.438361 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:11.489046 [ 34342 ] {3b976f23-9b25-4de2-8342-e9d146d20b98} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52416) (comment: 01854_HTTP_dict_decompression.sh) (in query: drop dictionary if exists test_table_select), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:49:11.497580 [ 34342 ] {3b976f23-9b25-4de2-8342-e9d146d20b98} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca8ad1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:11.524325 [ 5110 ] {366522f7-a3a1-44e9-90b1-6879a4e7e5c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 523, line 524) (in query: SELECT equals([], [], []);) 2025.06.13 15:49:11.546612 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:11.566681 [ 8430 ] {185461e2-5a08-46b2-bd4c-a110e1ab56bb} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:35c3ac0d-91f6-4b97-973f-f2e8eec47be6'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52434) (comment: 02482_new_json_nested_arrays_with_same_keys.sh) (in query: CREATE DATABASE IF NOT EXISTS test_46e4f5sl ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:11.575397 [ 8430 ] {185461e2-5a08-46b2-bd4c-a110e1ab56bb} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:35c3ac0d-91f6-4b97-973f-f2e8eec47be6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:11.643113 [ 5110 ] {3d9e5130-5548-4bad-b367-6f795decb421} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 524, line 525) (in query: SELECT erf([], [], []);) 2025.06.13 15:49:11.672043 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:11.795429 [ 5110 ] {d8f554d5-a583-4778-9974-b5640afc227e} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 525, line 526) (in query: SELECT erfc([], [], []);) 2025.06.13 15:49:11.807426 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:11.826773 [ 18602 ] {19ef5601-dbf2-471f-9670-027e22ed87fa} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:201e3e35-ebaa-4bcb-810b-e7eec8f26413'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52446) (comment: 00159_parallel_formatting_http.sh) (in query: CREATE DATABASE IF NOT EXISTS test_0w44qv1x ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:11.841420 [ 18602 ] {19ef5601-dbf2-471f-9670-027e22ed87fa} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:201e3e35-ebaa-4bcb-810b-e7eec8f26413'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:11.918100 [ 5110 ] {85a2d4fe-dc3c-4705-8323-e975d4510609} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 526, line 527) (in query: SELECT errorCodeToName([], [], []);) 2025.06.13 15:49:11.928391 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:12.073166 [ 5110 ] {ccf8a4b0-2177-4b69-8dc7-9303bc14f7c8} executeQuery: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 527, line 528) (in query: SELECT estimateCompressionRatio([], [], []);) 2025.06.13 15:49:12.088154 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:12.101891 [ 8430 ] {438cc49d-3e95-4642-84d6-dcf20824ca99} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:3a9aae3e-f0b5-458b-be5c-852cec33cd3e'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52456) (comment: 00474_readonly_settings.sh) (in query: CREATE DATABASE IF NOT EXISTS test_jm1cka07 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:12.105777 [ 8430 ] {438cc49d-3e95-4642-84d6-dcf20824ca99} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:3a9aae3e-f0b5-458b-be5c-852cec33cd3e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:12.179768 [ 5110 ] {673d9901-0a7a-46b9-9371-93160610c108} executeQuery: Code: 43. DB::Exception: Argument for function evalMLMethod must have type AggregateFunction - state of aggregate function.: In scope SELECT evalMLMethod([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 528, line 529) (in query: SELECT evalMLMethod([], [], []);) 2025.06.13 15:49:12.220837 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function evalMLMethod must have type AggregateFunction - state of aggregate function.: In scope SELECT evalMLMethod([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:12.371381 [ 7279 ] {4f2582e3-52fc-4ee1-bf80-43f2ce31dad0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:899af353-a77c-455c-ab52-f1def31331b4'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52458) (comment: 02725_local_query_parameters.sh) (in query: CREATE DATABASE IF NOT EXISTS test_ixb3v01f ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:12.374214 [ 7279 ] {4f2582e3-52fc-4ee1-bf80-43f2ce31dad0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:899af353-a77c-455c-ab52-f1def31331b4'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:12.378197 [ 8101 ] {cbca419c-7189-438b-8ff2-eeee14663833} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1172, line 1172) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt8(1) as r FORMAT CSV;) 2025.06.13 15:49:12.379009 [ 5110 ] {0e4b246b-3415-41c8-96ec-c1a1cb811a79} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 529, line 530) (in query: SELECT exp([], [], []);) 2025.06.13 15:49:12.393579 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:12.405774 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:12.627912 [ 5110 ] {d41ec775-4423-41b3-a67b-5f920382f2ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 530, line 531) (in query: SELECT exp10([], [], []);) 2025.06.13 15:49:12.655253 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:12.687279 [ 18602 ] {b252e3fb-3e37-4b1d-8bb0-d01f5d8d2efc} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:0df43dfd-0f7e-4f77-a4b6-32c22985dbce'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52496) (comment: 02115_rewrite_local_join_right_distribute_table.sql) (in query: CREATE DATABASE IF NOT EXISTS test_54mq9f8c ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:12.701722 [ 18602 ] {b252e3fb-3e37-4b1d-8bb0-d01f5d8d2efc} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:0df43dfd-0f7e-4f77-a4b6-32c22985dbce'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:12.824289 [ 5110 ] {21ed19d4-3848-46fa-b050-1165c81bc62b} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 531, line 532) (in query: SELECT exp2([], [], []);) 2025.06.13 15:49:12.864067 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:12.925614 [ 3821 ] {6f34f237-1e66-48e3-8102-a077233879f2} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:bae268e5-2335-4da5-8d8c-6e95ce954cfe'. (REPLICA_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52538) (comment: 01455_rank_correlation_spearman.sql) (in query: CREATE DATABASE IF NOT EXISTS test_hemdhimm ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:12.930301 [ 3821 ] {6f34f237-1e66-48e3-8102-a077233879f2} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '6c2391fa62b7:9000:228793f2-0099-4d58-957f-b727f1e42562', current host ID: '6c2391fa62b7:9000:bae268e5-2335-4da5-8d8c-6e95ce954cfe'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002c798497 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:492: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002c75c246 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:733: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002c7628e7 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000002dc9b77a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc54e8f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:12.993856 [ 5110 ] {3ccac1e2-be32-4e13-b8c3-bfcee299941f} executeQuery: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 532, line 533) (in query: SELECT exponentialMovingAverage([], [], []);) 2025.06.13 15:49:13.021615 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:13.249491 [ 5110 ] {f6373a47-dee4-464e-a09a-968d8e6b09df} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 533, line 534) (in query: SELECT exponentialTimeDecayedAvg([], [], []);) 2025.06.13 15:49:13.261594 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:13.361447 [ 5110 ] {fcd6bb94-605e-4155-8027-abd6ce0fcfa4} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 534, line 535) (in query: SELECT exponentialTimeDecayedCount([], [], []);) 2025.06.13 15:49:13.408573 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:13.585213 [ 5110 ] {8432fe3c-4ee8-4437-ad3e-15d0b61eee4a} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 535, line 536) (in query: SELECT exponentialTimeDecayedMax([], [], []);) 2025.06.13 15:49:13.611536 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:13.651654 [ 8101 ] {000461fb-e618-4ee5-be86-0bc78449003b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1177, line 1177) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) >= N as r FORMAT CSV;) 2025.06.13 15:49:13.680067 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:13.798622 [ 5110 ] {08ac5358-2ac3-4eaf-8851-3c0ad4621830} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 536, line 537) (in query: SELECT exponentialTimeDecayedSum([], [], []);) 2025.06.13 15:49:13.815910 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:13.920188 [ 5110 ] {0720c19a-e7d4-4f07-8195-99405af4e24c} executeQuery: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 537, line 538) (in query: SELECT extract([], [], []);) 2025.06.13 15:49:13.944951 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:14.065095 [ 5110 ] {4ed6b525-c687-4ea6-b5f8-cc7308be6ecc} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 538, line 539) (in query: SELECT extractAll([], [], []);) 2025.06.13 15:49:14.097159 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:14.304871 [ 5110 ] {3613b3d8-c19e-4777-bbf8-7f946ff73550} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 539, line 540) (in query: SELECT extractAllGroups([], [], []);) 2025.06.13 15:49:14.312041 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:14.437540 [ 5110 ] {3ee144cd-dd5d-4747-8909-cc08601d9774} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 540, line 541) (in query: SELECT extractAllGroupsHorizontal([], [], []);) 2025.06.13 15:49:14.458247 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:14.612194 [ 5110 ] {0087aef9-d38a-4998-9441-2aae69f17831} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 541, line 542) (in query: SELECT extractAllGroupsVertical([], [], []);) 2025.06.13 15:49:14.645149 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:14.689647 [ 8101 ] {c1fa0d34-2cc2-4598-8394-eb7aeae471ea} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1182, line 1182) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt8(-1) as r FORMAT CSV;) 2025.06.13 15:49:14.704685 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:14.756176 [ 5110 ] {330b36c4-6367-4b02-8633-cd2ccacb8123} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 542, line 543) (in query: SELECT extractGroups([], [], []);) 2025.06.13 15:49:14.783449 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:14.840627 [ 8430 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_memory_usage shouldn't be greater than 10000000000. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:49:14.846900 [ 8430 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:49:14.987365 [ 5110 ] {ba03a57d-a839-438e-b1d5-021aac28ae3a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairs([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 543, line 544) (in query: SELECT extractKeyValuePairs([], [], []);) 2025.06.13 15:49:15.012093 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairs([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:15.290067 [ 5110 ] {6e59680e-2c80-4e3a-a88f-ef36486e1e30} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairsWithEscaping([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 544, line 545) (in query: SELECT extractKeyValuePairsWithEscaping([], [], []);) 2025.06.13 15:49:15.316152 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairsWithEscaping([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:15.458648 [ 5110 ] {1f4d215a-5c31-4ee4-9734-846755228906} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 545, line 546) (in query: SELECT extractTextFromHTML([], [], []);) 2025.06.13 15:49:15.477865 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:15.699499 [ 5110 ] {1798a4e9-2ff8-42a6-951a-12fdc3e17a35} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 546, line 547) (in query: SELECT extractURLParameter([], [], []);) 2025.06.13 15:49:15.719700 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:15.858618 [ 8101 ] {d182eec9-4496-4c81-8e4d-b2db09701100} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1187, line 1187) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) >= N as r FORMAT CSV;) 2025.06.13 15:49:15.874310 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:15.968760 [ 5110 ] {079ad4b2-82b1-41c2-aa6e-83fed83bf96b} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 547, line 548) (in query: SELECT extractURLParameterNames([], [], []);) 2025.06.13 15:49:15.974706 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:16.139004 [ 5110 ] {270710c0-1db5-4551-b572-249c80978bb8} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 548, line 549) (in query: SELECT extractURLParameters([], [], []);) 2025.06.13 15:49:16.165107 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:16.317869 [ 5110 ] {b8bb0cfe-b344-493e-80b7-345121697893} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 549, line 550) (in query: SELECT factorial([], [], []);) 2025.06.13 15:49:16.328843 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:16.633270 [ 34301 ] {c25e5c46-6651-4063-8fd1-8a47fbf8212f} 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.20286.altinityantalya (altinity build)) (from [::1]:57168) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871846f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5168: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc558aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:49:16.646586 [ 34301 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000001871846f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5168: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc558aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5343: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc21 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:49:16.740553 [ 8430 ] {35a3cc38-b8ba-4100-b1aa-4e80ab02665e} executeQuery: Code: 57. DB::Exception: Table test_3.users already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52144) (comment: 01936_empty_function_support_uuid.sql) (query 6, line 16) (in query: CREATE TABLE users (user_id UUID) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:16.784506 [ 8430 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.users already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:17.002300 [ 8101 ] {b600f0b9-6c51-4769-b201-040dac579234} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1192, line 1192) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt16(1) as r FORMAT CSV;) 2025.06.13 15:49:17.017886 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:17.130949 [ 5110 ] {4caf3b99-d181-4193-97bf-f78e8ce8184d} executeQuery: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 552, line 553) (in query: SELECT file([], [], []);) 2025.06.13 15:49:17.143689 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:17.307502 [ 5110 ] {b1eb5e03-c278-4635-9301-f50129f2debc} executeQuery: Code: 42. DB::Exception: Arguments size of function filesystemAvailable should be 0 or 1: In scope SELECT filesystemAvailable([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 553, line 554) (in query: SELECT filesystemAvailable([], [], []);) 2025.06.13 15:49:17.312862 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function filesystemAvailable should be 0 or 1: In scope SELECT filesystemAvailable([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:17.392312 [ 5110 ] {9cebd862-0503-45f7-9ee2-8eafc2d72517} executeQuery: Code: 42. DB::Exception: Arguments size of function filesystemCapacity should be 0 or 1: In scope SELECT filesystemCapacity([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 554, line 555) (in query: SELECT filesystemCapacity([], [], []);) 2025.06.13 15:49:17.398894 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function filesystemCapacity should be 0 or 1: In scope SELECT filesystemCapacity([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:17.568672 [ 5110 ] {33254324-4fd5-45e4-ac88-939d9dc33c41} executeQuery: Code: 42. DB::Exception: Arguments size of function filesystemUnreserved should be 0 or 1: In scope SELECT filesystemUnreserved([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 555, line 556) (in query: SELECT filesystemUnreserved([], [], []);) 2025.06.13 15:49:17.582701 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function filesystemUnreserved should be 0 or 1: In scope SELECT filesystemUnreserved([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:17.754014 [ 5110 ] {910db559-01e7-469f-ba4b-a0cf487b32f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 556, line 557) (in query: SELECT finalizeAggregation([], [], []);) 2025.06.13 15:49:17.774141 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:17.940559 [ 5110 ] {fdd68f87-a633-461b-bc60-159fa62c0e0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 557, line 558) (in query: SELECT firstLine([], [], []);) 2025.06.13 15:49:17.954565 [ 8101 ] {8fdd802b-7b79-4d56-a607-7832aa7e9254} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1197, line 1197) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) >= N as r FORMAT CSV;) 2025.06.13 15:49:17.958332 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:17.961427 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:18.084566 [ 5110 ] {8cf9c2d8-56a8-4ab7-8156-b3718cb2e8d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 558, line 559) (in query: SELECT firstSignificantSubdomain([], [], []);) 2025.06.13 15:49:18.105046 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:18.194678 [ 5110 ] {f94a5cc2-e954-45f9-b98b-54e8e57fc9f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 559, line 560) (in query: SELECT firstSignificantSubdomainCustom([], [], []);) 2025.06.13 15:49:18.204289 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:18.255143 [ 5110 ] {83d079ff-d0d3-47a4-aceb-03ed40a31d29} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 560, line 561) (in query: SELECT firstSignificantSubdomainCustomRFC([], [], []);) 2025.06.13 15:49:18.264931 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:18.363403 [ 5110 ] {24474d29-edb6-4a01-8a1d-b4a71f65d2c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 561, line 562) (in query: SELECT firstSignificantSubdomainRFC([], [], []);) 2025.06.13 15:49:18.372661 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:18.408432 [ 5110 ] {2c464da2-7a44-457d-a843-5f7e35abe11f} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 562, line 563) (in query: SELECT firstValueRespectNulls([], [], []);) 2025.06.13 15:49:18.414937 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:18.531089 [ 5110 ] {8d33cca1-1c5d-4eff-9e38-e9337483374b} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 563, line 564) (in query: SELECT first_value([], [], []);) 2025.06.13 15:49:18.542034 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:18.584725 [ 5110 ] {0c0b84f1-58f2-49c0-b0dc-34d37d891b41} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 564, line 565) (in query: SELECT first_value_respect_nulls([], [], []);) 2025.06.13 15:49:18.613745 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:18.739944 [ 5110 ] {130bac58-d8d6-4f9a-a556-3822ee48000e} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Array(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 565, line 566) (in query: SELECT flameGraph([], [], []);) 2025.06.13 15:49:18.752457 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Array(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:18.842029 [ 8101 ] {3a735d12-545e-43c4-88f6-17c8c0d87d8e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1202, line 1202) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt16(-1) as r FORMAT CSV;) 2025.06.13 15:49:18.853881 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:18.899849 [ 5110 ] {b877595f-321c-4b10-97a0-320480d65487} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 566, line 567) (in query: SELECT flatten([], [], []);) 2025.06.13 15:49:18.915095 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:19.063589 [ 5110 ] {541053e1-dc73-4727-8aca-2dc8ce83e60c} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 567, line 568) (in query: SELECT flattenTuple([], [], []);) 2025.06.13 15:49:19.096073 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:19.287771 [ 5110 ] {0d26aa0f-fb64-402f-a6cf-d932b519d9aa} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'floor'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT floor([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 568, line 569) (in query: SELECT floor([], [], []);) 2025.06.13 15:49:19.294156 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'floor'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT floor([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:19.435433 [ 5110 ] {b131da4b-cc8b-4fa1-9a0f-eb0fa4d00bfe} executeQuery: Code: 170. DB::Exception: Bad get: has Array, requested String: In scope SELECT format([], [], []). (BAD_GET) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 569, line 570) (in query: SELECT format([], [], []);) 2025.06.13 15:49:19.457107 [ 5110 ] {} TCPHandler: Code: 170. DB::Exception: Bad get: has Array, requested String: In scope SELECT format([], [], []). (BAD_GET) 2025.06.13 15:49:19.572326 [ 5110 ] {e4969945-85c0-4796-87a9-ed8e3cb80e1b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT formatDateTime([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 570, line 571) (in query: SELECT formatDateTime([], [], []);) 2025.06.13 15:49:19.601815 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT formatDateTime([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:19.688599 [ 5110 ] {ff658298-5d77-416f-8068-813ec764bf0a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function formatDateTimeInJodaSyntax. Should be a date or a date with time: In scope SELECT formatDateTimeInJodaSyntax([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 571, line 572) (in query: SELECT formatDateTimeInJodaSyntax([], [], []);) 2025.06.13 15:49:19.704994 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function formatDateTimeInJodaSyntax. Should be a date or a date with time: In scope SELECT formatDateTimeInJodaSyntax([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:19.884211 [ 5110 ] {f6515a92-9a4a-4fc3-8d7d-9b3911d396a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 572, line 573) (in query: SELECT formatQuery([], [], []);) 2025.06.13 15:49:19.895860 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:19.927398 [ 8101 ] {4267306a-9a2f-41e8-841c-607f6b9aa94c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1207, line 1207) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) >= N as r FORMAT CSV;) 2025.06.13 15:49:19.933234 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:20.044444 [ 5110 ] {0e4e908f-2f78-4efd-a61b-ecbfe490577a} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 573, line 574) (in query: SELECT formatQueryOrNull([], [], []);) 2025.06.13 15:49:20.051414 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:20.121103 [ 5110 ] {421c1eea-03ab-4a9e-be63-8e36d1bfc356} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 574, line 575) (in query: SELECT formatQuerySingleLine([], [], []);) 2025.06.13 15:49:20.168356 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:20.291582 [ 5110 ] {5c698a80-0d75-47af-8996-aa80cd339995} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 575, line 576) (in query: SELECT formatQuerySingleLineOrNull([], [], []);) 2025.06.13 15:49:20.314214 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:20.438457 [ 5110 ] {3297003e-1fa8-4f21-b07c-b6df0e44b832} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 576, line 577) (in query: SELECT formatReadableDecimalSize([], [], []);) 2025.06.13 15:49:20.459659 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:20.614620 [ 5110 ] {2d53bbe2-a2da-4737-9277-48538ef58910} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 577, line 578) (in query: SELECT formatReadableQuantity([], [], []);) 2025.06.13 15:49:20.684247 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:20.808218 [ 8101 ] {31ff056b-654a-4223-8e44-294f39d454f0} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1212, line 1212) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt32(1) as r FORMAT CSV;) 2025.06.13 15:49:20.814228 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:20.882238 [ 5110 ] {5d4bc270-2e0c-442f-be1a-738bc15f4c7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 578, line 579) (in query: SELECT formatReadableSize([], [], []);) 2025.06.13 15:49:20.891682 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:20.971044 [ 5110 ] {8396aad9-3315-4b85-9359-919dd2b29095} executeQuery: Code: 43. DB::Exception: Cannot format Array(Nothing) as time delta: In scope SELECT formatReadableTimeDelta([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 579, line 580) (in query: SELECT formatReadableTimeDelta([], [], []);) 2025.06.13 15:49:20.998859 [ 34359 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:20.999169 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Cannot format Array(Nothing) as time delta: In scope SELECT formatReadableTimeDelta([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:21.082348 [ 5110 ] {7b80f8f0-58a3-4e42-b729-44cd1375f809} executeQuery: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 580, line 581) (in query: SELECT formatRow([], [], []);) 2025.06.13 15:49:21.097943 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:21.171117 [ 5110 ] {9cd72c28-71a3-44ba-89cf-4180d18d420d} executeQuery: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 581, line 582) (in query: SELECT formatRowNoNewline([], [], []);) 2025.06.13 15:49:21.180128 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:21.280649 [ 6621 ] {67290d27-2f74-446d-a199-e8d8ef03d35e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.id, 42_UInt8) :: 0) -> throwIf(equals(__table1.id, 42_UInt8)) UInt8 : 1': while pushing to view test_9.async_insert_mv (44163a25-2d90-4b13-9666-f976cbbcb4e5). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 02790_async_queries_in_query_log.sh) (in query: INSERT INTO test_9.async_insert_landing (id) SETTINGS wait_for_async_insert = 1, async_insert = 1 FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:839: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000031f08065 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc241 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb001 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 27. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 28. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fea13 29. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 2025.06.13 15:49:21.291104 [ 5110 ] {7e3fd655-f576-4e4b-9e22-b8318419e0b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 582, line 583) (in query: SELECT fragment([], [], []);) 2025.06.13 15:49:21.311691 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:21.314366 [ 6621 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_9.async_insert_landing (id) SETTINGS wait_for_async_insert = 1, async_insert = 1 FORMAT Values': Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.id, 42_UInt8) :: 0) -> throwIf(equals(__table1.id, 42_UInt8)) UInt8 : 1': while pushing to view test_9.async_insert_mv (44163a25-2d90-4b13-9666-f976cbbcb4e5). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:839: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000031f08065 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc241 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb001 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 27. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 28. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fea13 29. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:317: DB::AsynchronousInsertQueue::scheduleDataProcessingJob(DB::AsynchronousInsertQueue::InsertQuery const&, std::unique_ptr>, std::shared_ptr, unsigned long) @ 0x000000002d3f30b9 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:532: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002d3f78e5 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f5ecf 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:21.336400 [ 8430 ] {btpdtfzbzm} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.id, 42_UInt8) :: 0) -> throwIf(equals(__table1.id, 42_UInt8)) UInt8 : 1': while pushing to view test_9.async_insert_mv (44163a25-2d90-4b13-9666-f976cbbcb4e5): While executing WaitForAsyncInsert. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52234) (comment: 02790_async_queries_in_query_log.sh) (query 1, line 1) (in query: INSERT INTO async_insert_landing SETTINGS wait_for_async_insert=1, async_insert=1 values ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:839: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000031f08065 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc241 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb001 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 27. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 28. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fea13 29. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 2025.06.13 15:49:21.348629 [ 8430 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.id, 42_UInt8) :: 0) -> throwIf(equals(__table1.id, 42_UInt8)) UInt8 : 1': while pushing to view test_9.async_insert_mv (44163a25-2d90-4b13-9666-f976cbbcb4e5): While executing WaitForAsyncInsert. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 19. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:839: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x0000000031f08065 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc241 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbb001 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 27. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 28. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000002d3fea13 29. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d40324b 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:317: DB::AsynchronousInsertQueue::scheduleDataProcessingJob(DB::AsynchronousInsertQueue::InsertQuery const&, std::unique_ptr>, std::shared_ptr, unsigned long) @ 0x000000002d3f30b9 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:532: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000002d3f78e5 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000002d3f5ecf 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a0e08 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:49:21.508000 [ 5110 ] {807c9d04-225e-4f46-a10e-984e4e7297cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 583, line 584) (in query: SELECT fromDaysSinceYearZero([], [], []);) 2025.06.13 15:49:21.532616 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:21.563984 [ 8101 ] {98cad82d-01cf-4b6b-9a82-75b62a2a3122} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1217, line 1217) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) >= N as r FORMAT CSV;) 2025.06.13 15:49:21.589338 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:21.675989 [ 5110 ] {a5fbc4b4-621a-402e-bb92-4a6182ba3009} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 584, line 585) (in query: SELECT fromDaysSinceYearZero32([], [], []);) 2025.06.13 15:49:21.774514 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:21.874288 [ 7279 ] {145969a7-eb66-461f-9416-682921215f84} executeQuery: Code: 80. DB::Exception: Cannot CREATE a table AS test_lozx3cqf.v, it is a View. (INCORRECT_QUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52222) (comment: 01056_create_table_as.sql) (query 16, line 20) (in query: CREATE TABLE t3 AS v;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1340: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x000000002dc68a24 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5de9a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:49:21.906151 [ 7279 ] {} TCPHandler: Code: 80. DB::Exception: Cannot CREATE a table AS test_lozx3cqf.v, it is a View. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1340: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x000000002dc68a24 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5de9a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:49:21.931685 [ 5110 ] {f50e3379-5741-4be9-af97-3fc07525ff27} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 585, line 586) (in query: SELECT fromModifiedJulianDay([], [], []);) 2025.06.13 15:49:21.958185 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:22.142667 [ 5110 ] {64fe1158-a9a1-49d4-8db1-c5dc82ffbc37} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 586, line 587) (in query: SELECT fromModifiedJulianDayOrNull([], [], []);) 2025.06.13 15:49:22.154595 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:22.210794 [ 5110 ] {8aa1940c-58e2-4e60-83b9-4fdc5e0e62a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 587, line 588) (in query: SELECT fromUTCTimestamp([], [], []);) 2025.06.13 15:49:22.231974 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:22.359966 [ 5110 ] {3a7a1ac8-3c6a-435d-95db-b45a7d3a4a38} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestamp([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 588, line 589) (in query: SELECT fromUnixTimestamp([], [], []);) 2025.06.13 15:49:22.372119 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestamp([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:22.437349 [ 5110 ] {f786c561-83ff-4b99-bc5a-fcf801d19534} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Micro takes one or two arguments: In scope SELECT fromUnixTimestamp64Micro([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 589, line 590) (in query: SELECT fromUnixTimestamp64Micro([], [], []);) 2025.06.13 15:49:22.443588 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Micro takes one or two arguments: In scope SELECT fromUnixTimestamp64Micro([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:22.493810 [ 5110 ] {d1a3387a-7f36-4cc7-babb-e29a482f0663} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Milli takes one or two arguments: In scope SELECT fromUnixTimestamp64Milli([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 590, line 591) (in query: SELECT fromUnixTimestamp64Milli([], [], []);) 2025.06.13 15:49:22.501687 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Milli takes one or two arguments: In scope SELECT fromUnixTimestamp64Milli([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:22.555643 [ 5110 ] {9824052b-37ea-4912-9516-3a38dca4efd3} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Nano takes one or two arguments: In scope SELECT fromUnixTimestamp64Nano([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 591, line 592) (in query: SELECT fromUnixTimestamp64Nano([], [], []);) 2025.06.13 15:49:22.570303 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Nano takes one or two arguments: In scope SELECT fromUnixTimestamp64Nano([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:22.608664 [ 8101 ] {8e20280b-d876-4ff2-95b8-f2168f06b077} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1222, line 1222) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt32(-1) as r FORMAT CSV;) 2025.06.13 15:49:22.622519 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:22.640296 [ 5110 ] {1e0085c6-606e-4058-8182-eddab2726756} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Second takes one or two arguments: In scope SELECT fromUnixTimestamp64Second([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 592, line 593) (in query: SELECT fromUnixTimestamp64Second([], [], []);) 2025.06.13 15:49:22.651407 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Second takes one or two arguments: In scope SELECT fromUnixTimestamp64Second([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:22.705757 [ 5110 ] {4345ad6f-2df7-4851-a5e5-72ccba681a07} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestampInJodaSyntax when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestampInJodaSyntax([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 593, line 594) (in query: SELECT fromUnixTimestampInJodaSyntax([], [], []);) 2025.06.13 15:49:22.722953 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestampInJodaSyntax when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestampInJodaSyntax([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:22.774656 [ 5110 ] {8371ca6a-55d7-4083-b2bf-460f968d1726} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 594, line 595) (in query: SELECT from_utc_timestamp([], [], []);) 2025.06.13 15:49:22.784757 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:22.919961 [ 7279 ] {9e3ded38-189e-4e9d-ba55-77221dfcdd0b} executeQuery: Code: 80. DB::Exception: Cannot CREATE a table AS test_lozx3cqf.dict, it is a Dictionary. (INCORRECT_QUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52222) (comment: 01056_create_table_as.sql) (query 23, line 39) (in query: CREATE TABLE t3 AS dict;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1358: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x000000002dc68cf8 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5de9a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:49:22.940078 [ 7279 ] {} TCPHandler: Code: 80. DB::Exception: Cannot CREATE a table AS test_lozx3cqf.dict, it is a Dictionary. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1358: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x000000002dc68cf8 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5de9a 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:49:22.949742 [ 5110 ] {06af5ce9-b96c-4e2f-9208-85def479e4fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 595, line 596) (in query: SELECT fullHostName([], [], []);) 2025.06.13 15:49:22.965232 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:23.163634 [ 5110 ] {50d2c520-9a2e-4483-b589-912588944beb} executeQuery: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 596, line 597) (in query: SELECT fuzzBits([], [], []);) 2025.06.13 15:49:23.175463 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:23.432275 [ 8101 ] {e3bde980-3941-4d1b-b6e2-3959793c9b08} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1227, line 1227) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) >= N as r FORMAT CSV;) 2025.06.13 15:49:23.447587 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:23.476455 [ 5110 ] {34c2ddbd-ab1a-404a-9ee1-212bd5f205aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 598, line 599) (in query: SELECT gcd([], [], []);) 2025.06.13 15:49:23.510995 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:23.625883 [ 5110 ] {15782b92-974a-400e-b47a-62637615cee6} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 599, line 600) (in query: SELECT generateRandomStructure([], [], []);) 2025.06.13 15:49:23.638206 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:23.806657 [ 5110 ] {68828a30-5241-42fb-99ed-09f1e04df60f} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 3, should be 1: In scope SELECT generateSerialID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 600, line 601) (in query: SELECT generateSerialID([], [], []);) 2025.06.13 15:49:23.820433 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 3, should be 1: In scope SELECT generateSerialID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:23.925286 [ 5110 ] {9880d3bb-56e7-4184-9885-9032ccee97c7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 601, line 602) (in query: SELECT generateSnowflakeID([], [], []);) 2025.06.13 15:49:23.938952 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:24.028772 [ 5110 ] {608951b0-a6c9-4338-a132-376b84a26ba4} executeQuery: Code: 34. DB::Exception: Number of arguments for function generateULID doesn't match: passed 3, should be 0 or 1.: In scope SELECT generateULID([], [], []). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 602, line 603) (in query: SELECT generateULID([], [], []);) 2025.06.13 15:49:24.048823 [ 5110 ] {} TCPHandler: Code: 34. DB::Exception: Number of arguments for function generateULID doesn't match: passed 3, should be 0 or 1.: In scope SELECT generateULID([], [], []). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:49:24.188673 [ 5110 ] {41476e14-105e-4449-b178-9ad593910f86} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 603, line 604) (in query: SELECT generateUUIDv4([], [], []);) 2025.06.13 15:49:24.278457 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:24.299968 [ 8101 ] {fafea0aa-c4fa-481f-a97f-081c2a32384a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1232, line 1232) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt64(1) as r FORMAT CSV;) 2025.06.13 15:49:24.309423 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:24.424160 [ 5110 ] {cf9e878b-c590-4acf-81f3-77021b21f63c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 604, line 605) (in query: SELECT generateUUIDv7([], [], []);) 2025.06.13 15:49:24.460981 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:24.700855 [ 5110 ] {96bfad3f-9dc5-45b3-a112-55ce14c6fa22} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 605, line 606) (in query: SELECT geoDistance([], [], []);) 2025.06.13 15:49:24.763300 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:24.894512 [ 5110 ] {27b77211-b376-440f-981a-1f15e0a4a985} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function geoToH3. Must be Float64: In scope SELECT geoToH3([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 606, line 607) (in query: SELECT geoToH3([], [], []);) 2025.06.13 15:49:24.909821 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function geoToH3. Must be Float64: In scope SELECT geoToH3([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:25.059263 [ 5110 ] {788ac1e2-04e7-4faa-9f9f-315256d89189} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 607, line 608) (in query: SELECT geoToS2([], [], []);) 2025.06.13 15:49:25.070448 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:25.313108 [ 5110 ] {ea2574e6-f3bd-4006-bd9a-2ab51afe8f14} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 608, line 609) (in query: SELECT geohashDecode([], [], []);) 2025.06.13 15:49:25.333648 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:25.436894 [ 5110 ] {349ca18c-4e1c-4f5e-aedc-03e77815bb05} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'longitude' to function 'geohashEncode'. Expected: Float*, got: Array(Nothing): In scope SELECT geohashEncode([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 609, line 610) (in query: SELECT geohashEncode([], [], []);) 2025.06.13 15:49:25.447665 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'longitude' to function 'geohashEncode'. Expected: Float*, got: Array(Nothing): In scope SELECT geohashEncode([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:25.461154 [ 8101 ] {fce3c20b-446a-4398-b6bb-f659b5f0ef2c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1237, line 1237) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) >= N as r FORMAT CSV;) 2025.06.13 15:49:25.467227 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:25.584566 [ 5110 ] {8711970b-a0d0-49d4-9024-ae5fe5209ab4} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 610, line 611) (in query: SELECT geohashesInBox([], [], []);) 2025.06.13 15:49:25.606193 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:25.689697 [ 5110 ] {61a655a1-b41f-47d4-ba72-22aede70a9d9} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 611, line 612) (in query: SELECT getClientHTTPHeader([], [], []);) 2025.06.13 15:49:25.719027 [ 5110 ] {} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.06.13 15:49:25.896410 [ 5110 ] {e1626cd6-9cbc-482c-8d42-3c46d296913b} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 612, line 613) (in query: SELECT getMacro([], [], []);) 2025.06.13 15:49:25.924825 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:26.032217 [ 5110 ] {0e811b77-cb67-4c03-88c1-b3c8fafa3ff4} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 3, should be 1: In scope SELECT getMaxTableNameLengthForDatabase([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 613, line 614) (in query: SELECT getMaxTableNameLengthForDatabase([], [], []);) 2025.06.13 15:49:26.053528 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 3, should be 1: In scope SELECT getMaxTableNameLengthForDatabase([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:26.200853 [ 5110 ] {c0c699dd-4fd6-4a69-b04a-64c2704528e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 614, line 615) (in query: SELECT getOSKernelVersion([], [], []);) 2025.06.13 15:49:26.218433 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:26.339870 [ 5110 ] {7825d637-6308-42d6-afb5-4393ee06c6da} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 615, line 616) (in query: SELECT getServerPort([], [], []);) 2025.06.13 15:49:26.349035 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:26.400671 [ 5110 ] {6b1b2a48-6679-45d3-b253-7393aca08720} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 616, line 617) (in query: SELECT getSetting([], [], []);) 2025.06.13 15:49:26.413832 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:26.426977 [ 8101 ] {764cfde3-d529-4966-8e3e-b2095864ed36} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1242, line 1242) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt64(-1) as r FORMAT CSV;) 2025.06.13 15:49:26.459338 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:26.528341 [ 3506 ] {} 3b89ff6a-80ea-4c72-99cc-8a7a6c91be4c::all_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003274a21c 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:16: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x00000000327488dc 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2181: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000305cfcab 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x000000003100928e 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000310af08c 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000310ac839 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:26.530289 [ 3506 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3b89ff6a-80ea-4c72-99cc-8a7a6c91be4c::all_0_0_0_2}: Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003274a21c 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:16: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x00000000327488dc 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2181: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000305cfcab 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x000000003100928e 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000310af08c 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000310ac839 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:26.614459 [ 5110 ] {e8d3f147-2611-4b92-a3a9-f10be53e2060} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 3, should be 2: In scope SELECT getSettingOrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 617, line 618) (in query: SELECT getSettingOrDefault([], [], []);) 2025.06.13 15:49:26.633664 [ 3508 ] {} 3b89ff6a-80ea-4c72-99cc-8a7a6c91be4c::all_1_1_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003274a21c 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:16: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x00000000327488dc 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2181: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000305cfcab 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x000000003100928e 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000310af08c 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000310ac839 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:26.635689 [ 3508 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3b89ff6a-80ea-4c72-99cc-8a7a6c91be4c::all_1_1_0_2}: Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000003274a21c 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:16: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x00000000327488dc 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2181: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x00000000305cfcab 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x000000003100928e 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000310af08c 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000310ac839 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:26.635737 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 3, should be 2: In scope SELECT getSettingOrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:26.802140 [ 5110 ] {e78fdf86-064f-44fd-815d-8cb64fdd2e1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 618, line 619) (in query: SELECT getSizeOfEnumType([], [], []);) 2025.06.13 15:49:26.818131 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:26.915201 [ 5110 ] {0ab695b6-8bc0-4cbc-b200-92080dd862b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 619, line 620) (in query: SELECT getSubcolumn([], [], []);) 2025.06.13 15:49:26.940833 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:27.035293 [ 5110 ] {305442a0-b315-4796-ad85-b879082de592} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 620, line 621) (in query: SELECT getTypeSerializationStreams([], [], []);) 2025.06.13 15:49:27.056080 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:27.145003 [ 5110 ] {c27396c3-1c98-4421-9dab-6ab9e16da0b0} executeQuery: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 621, line 622) (in query: SELECT globalIn([], [], []);) 2025.06.13 15:49:27.163858 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:27.309861 [ 5110 ] {36626843-e479-489c-8b9e-73e20e685c63} executeQuery: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 622, line 623) (in query: SELECT globalInIgnoreSet([], [], []);) 2025.06.13 15:49:27.318048 [ 3894 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:27.338404 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:27.444316 [ 8101 ] {b046a457-1f6d-41ee-93e8-82f165659a5d} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42136) (comment: 00921_datetime64_compatibility_long.sh) (query 1247, line 1247) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) >= N as r FORMAT CSV;) 2025.06.13 15:49:27.451335 [ 5110 ] {2ca87608-381e-47b1-97ce-8254fdff7f63} executeQuery: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 623, line 624) (in query: SELECT globalNotIn([], [], []);) 2025.06.13 15:49:27.454130 [ 8101 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:27.492452 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:27.604220 [ 5110 ] {36aee063-f370-4f87-86e5-a765ee5c9639} executeQuery: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 624, line 625) (in query: SELECT globalNotInIgnoreSet([], [], []);) 2025.06.13 15:49:27.621750 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:27.692214 [ 5110 ] {576f70fb-6be5-4784-83f9-69451ce94b03} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 625, line 626) (in query: SELECT globalNotNullIn([], [], []);) 2025.06.13 15:49:27.707134 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:27.874280 [ 5110 ] {79a65eb2-6323-4655-8bb5-3133ed52a9b4} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 626, line 627) (in query: SELECT globalNotNullInIgnoreSet([], [], []);) 2025.06.13 15:49:27.893583 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:27.997335 [ 5110 ] {8b4f7a41-0f5b-4de9-9f26-84728e51e7fb} executeQuery: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 627, line 628) (in query: SELECT globalNullIn([], [], []);) 2025.06.13 15:49:28.014527 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:28.111652 [ 5110 ] {fee701cf-ea77-43d8-879c-1367f84e321f} executeQuery: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 628, line 629) (in query: SELECT globalNullInIgnoreSet([], [], []);) 2025.06.13 15:49:28.126316 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:28.236809 [ 5110 ] {8caf097e-d2c4-42f8-9558-f29cdbfeff82} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 629, line 630) (in query: SELECT globalVariable([], [], []);) 2025.06.13 15:49:28.260191 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:28.323585 [ 5110 ] {456fe476-9aeb-410f-bd14-dad211d648e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 630, line 631) (in query: SELECT greatCircleAngle([], [], []);) 2025.06.13 15:49:28.338225 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:28.421123 [ 5110 ] {3b84e992-6963-43e5-a92b-54f0d4964dac} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 631, line 632) (in query: SELECT greatCircleDistance([], [], []);) 2025.06.13 15:49:28.476433 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:28.555678 [ 5110 ] {96357bb9-d01a-4bfb-8262-57c193957fc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 632, line 633) (in query: SELECT greater([], [], []);) 2025.06.13 15:49:28.563188 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:28.702114 [ 5110 ] {598a14e8-c924-4acf-9c96-7cbd2e8ba58e} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 633, line 634) (in query: SELECT greaterOrEquals([], [], []);) 2025.06.13 15:49:28.776678 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:29.094210 [ 5110 ] {4c37832d-f63c-4f8c-8702-dba0eee4554c} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 635, line 636) (in query: SELECT groupArray([], [], []);) 2025.06.13 15:49:29.188108 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:29.279727 [ 5110 ] {cf604bf4-e3fe-4e86-9069-e35dfde5210e} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 636, line 637) (in query: SELECT groupArrayInsertAt([], [], []);) 2025.06.13 15:49:29.311853 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:29.431880 [ 5110 ] {a07e8a02-9bd2-4f05-8552-fb6b055b5257} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayIntersect requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 637, line 638) (in query: SELECT groupArrayIntersect([], [], []);) 2025.06.13 15:49:29.453870 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayIntersect requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:29.601238 [ 5110 ] {c983df00-f75c-4572-81b6-c1c830c5dfd0} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 638, line 639) (in query: SELECT groupArrayLast([], [], []);) 2025.06.13 15:49:29.624817 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:29.750010 [ 5110 ] {392f25d9-c70e-4e83-a3e1-66ff5458c474} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayMovingAvg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 639, line 640) (in query: SELECT groupArrayMovingAvg([], [], []);) 2025.06.13 15:49:29.785533 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayMovingAvg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:29.914642 [ 5110 ] {7acb6813-b7b1-4ee5-b193-54deddeab669} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayMovingSum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 640, line 641) (in query: SELECT groupArrayMovingSum([], [], []);) 2025.06.13 15:49:29.936200 [ 34370 ] {4f884cf8-2841-4dc5-8606-894681e707d3} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC')). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38894) (comment: 02507_to_unix_timestamp_overflow.sql) (query 1, line 1) (in query: SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl(DB::DateTime64 const&, unsigned int, unsigned int&) @ 0x000000002c4a45ee 6. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>(T::FieldType const&, unsigned int) @ 0x000000002c4ac659 7. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUnixTimestamp, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b22bf5f 8. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b2259a6 9. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, 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::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02e6b7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b067c1e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b066a83 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:49:29.936605 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayMovingSum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:29.947374 [ 34370 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toUnixTimestamp(toDateTime64('1928-12-31 12:12:12.123', 3, 'UTC')). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl(DB::DateTime64 const&, unsigned int, unsigned int&) @ 0x000000002c4a45ee 6. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>(T::FieldType const&, unsigned int) @ 0x000000002c4ac659 7. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUnixTimestamp, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b22bf5f 8. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b2259a6 9. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, 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::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02e6b7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b067c1e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b066a83 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:49:30.077478 [ 5110 ] {00dfec72-738c-40f2-aacc-36693adee82b} executeQuery: Code: 42. DB::Exception: Aggregate function groupArraySample requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 641, line 642) (in query: SELECT groupArraySample([], [], []);) 2025.06.13 15:49:30.095890 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArraySample requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:30.169020 [ 5110 ] {1ee22f71-3a16-4a92-bb2b-ea9a9e3e4920} executeQuery: Code: 42. DB::Exception: Aggregate function groupArraySorted requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 642, line 643) (in query: SELECT groupArraySorted([], [], []);) 2025.06.13 15:49:30.188628 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArraySorted requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:30.326162 [ 5110 ] {f051558f-46b9-4b50-9e7c-777c0c9307ac} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 643, line 644) (in query: SELECT groupBitAnd([], [], []);) 2025.06.13 15:49:30.359116 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:30.561151 [ 5110 ] {5dd98e92-5f5a-48e8-83c7-c28d67c325d3} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 644, line 645) (in query: SELECT groupBitOr([], [], []);) 2025.06.13 15:49:30.568434 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:30.696433 [ 5110 ] {af91f85d-fd12-46d0-9438-abf73ae953c6} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 645, line 646) (in query: SELECT groupBitXor([], [], []);) 2025.06.13 15:49:30.705217 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:30.811929 [ 5110 ] {869dd462-b9ee-42d4-9184-c8dba141fa05} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmap requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 646, line 647) (in query: SELECT groupBitmap([], [], []);) 2025.06.13 15:49:30.820295 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmap requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:30.897664 [ 5110 ] {12820e74-73bc-4bbd-b07c-5f008e364059} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 647, line 648) (in query: SELECT groupBitmapAnd([], [], []);) 2025.06.13 15:49:30.918859 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:31.079313 [ 5110 ] {fae3f31d-82af-4513-b158-4af126180033} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 648, line 649) (in query: SELECT groupBitmapOr([], [], []);) 2025.06.13 15:49:31.142009 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:31.260272 [ 5110 ] {0efc1a4d-6740-4520-b9a6-e08a52591592} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 649, line 650) (in query: SELECT groupBitmapXor([], [], []);) 2025.06.13 15:49:31.275880 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:31.332512 [ 3502 ] {ca4f3309-a731-4074-8e76-b543813bed4d::202506_221_236_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c14c18 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c06f6e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:31.343195 [ 3502 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ca4f3309-a731-4074-8e76-b543813bed4d::202506_221_236_3}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c14c18 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c06f6e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:31.418155 [ 5110 ] {989e4eed-53d5-4df1-9733-99ae7024b760} executeQuery: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 650, line 651) (in query: SELECT groupConcat([], [], []);) 2025.06.13 15:49:31.426208 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:31.499032 [ 5110 ] {1cd9cba7-b374-432b-9b27-75ba71129972} executeQuery: Code: 42. DB::Exception: Aggregate function groupUniqArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 651, line 652) (in query: SELECT groupUniqArray([], [], []);) 2025.06.13 15:49:31.509311 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupUniqArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:31.577384 [ 5110 ] {6660b856-3ae5-4551-a800-6f1de969ad3a} executeQuery: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 652, line 653) (in query: SELECT group_concat([], [], []);) 2025.06.13 15:49:31.594702 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:31.721296 [ 5110 ] {5ed21932-6b2f-48f2-8446-775a4848f48a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 653, line 654) (in query: SELECT h3CellAreaM2([], [], []);) 2025.06.13 15:49:31.741347 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:31.902863 [ 5110 ] {c9245611-f1fe-4f8e-b6c3-47bc393180dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 654, line 655) (in query: SELECT h3CellAreaRads2([], [], []);) 2025.06.13 15:49:31.914616 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:32.006333 [ 5110 ] {770c5bdb-2f21-4522-b2bc-d4302f5f511f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 655, line 656) (in query: SELECT h3Distance([], [], []);) 2025.06.13 15:49:32.014574 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:32.084916 [ 5110 ] {af374f83-0e98-4f08-a50b-95f3b9e04b47} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 656, line 657) (in query: SELECT h3EdgeAngle([], [], []);) 2025.06.13 15:49:32.092690 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:32.268312 [ 5110 ] {605a9347-5dc3-40e2-964c-a144b23bf338} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 657, line 658) (in query: SELECT h3EdgeLengthKm([], [], []);) 2025.06.13 15:49:32.277690 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:32.343285 [ 5110 ] {fa89be64-5238-4a63-8df6-bfc7a8f24768} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 658, line 659) (in query: SELECT h3EdgeLengthM([], [], []);) 2025.06.13 15:49:32.371698 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:32.553442 [ 5110 ] {7de3bed5-41d5-4375-95fc-681cb648968f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 659, line 660) (in query: SELECT h3ExactEdgeLengthKm([], [], []);) 2025.06.13 15:49:32.596047 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:32.751678 [ 5110 ] {32a38ad3-2e84-47cd-9748-6bd3a66bcf8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 660, line 661) (in query: SELECT h3ExactEdgeLengthM([], [], []);) 2025.06.13 15:49:32.768720 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:32.873289 [ 5110 ] {4a93a284-5b6a-4f6d-88cf-68d28e77d36c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 661, line 662) (in query: SELECT h3ExactEdgeLengthRads([], [], []);) 2025.06.13 15:49:32.894922 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:33.039283 [ 5110 ] {d498e0b0-689d-4a0d-b669-eeb2defcc949} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 662, line 663) (in query: SELECT h3GetBaseCell([], [], []);) 2025.06.13 15:49:33.055219 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:33.277370 [ 5110 ] {2c37ae10-08d1-4548-a00e-bd9696e7618a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 663, line 664) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge([], [], []);) 2025.06.13 15:49:33.285344 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:33.457905 [ 5110 ] {7698199c-1347-45ab-b82a-593877274370} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 664, line 665) (in query: SELECT h3GetFaces([], [], []);) 2025.06.13 15:49:33.486585 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:33.636687 [ 5110 ] {332403c1-eff7-4a98-b237-ec4d5a68419b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 665, line 666) (in query: SELECT h3GetIndexesFromUnidirectionalEdge([], [], []);) 2025.06.13 15:49:33.667446 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:33.883573 [ 5110 ] {22bd58c7-b84d-4cf6-a70c-73fdb0658374} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 666, line 667) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge([], [], []);) 2025.06.13 15:49:33.901375 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:34.156547 [ 5110 ] {034460d3-b103-438d-885a-f44f1e003d13} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 667, line 668) (in query: SELECT h3GetPentagonIndexes([], [], []);) 2025.06.13 15:49:34.206123 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:34.340655 [ 5110 ] {abbbb686-a21d-4e12-9765-eddcd0234e0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 668, line 669) (in query: SELECT h3GetRes0Indexes([], [], []);) 2025.06.13 15:49:34.356963 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:34.489624 [ 5110 ] {a6ec57f6-fb69-4667-8e8e-534f08c0aede} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 669, line 670) (in query: SELECT h3GetResolution([], [], []);) 2025.06.13 15:49:34.496781 [ 18510 ] {93ae187a-5b92-40e6-8035-8e9e6a36b2a9} executeQuery: Code: 57. DB::Exception: Table test_15.t0 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46616) (comment: 02911_cte_invalid_query_analysis.sql) (query 4, line 5) (in query: CREATE TABLE t0 (`pkey` UInt32, `c1` UInt32) ENGINE = MergeTree PRIMARY KEY pkey SETTINGS index_granularity = 50368, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 67, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 169479402, compact_parts_max_granules_to_buffer = 209, compact_parts_merge_max_bytes_to_prefetch_part = 18458464, merge_max_block_size = 416, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 6517028558, index_granularity_bytes = 30191355, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 44, 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 = 12282, primary_key_compress_block_size = 16221, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:34.500657 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:34.536521 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.t0 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:34.724757 [ 5110 ] {a19ffe9c-ba4d-4b49-bb92-d1dd3dd462a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 670, line 671) (in query: SELECT h3GetUnidirectionalEdge([], [], []);) 2025.06.13 15:49:34.742773 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:34.887511 [ 5110 ] {a7bc8c62-be39-4803-9e05-872f5e4ff6ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 671, line 672) (in query: SELECT h3GetUnidirectionalEdgeBoundary([], [], []);) 2025.06.13 15:49:34.913153 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:35.033677 [ 5110 ] {ca7168a7-ca74-4ab6-8bf7-f5632667d855} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 672, line 673) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon([], [], []);) 2025.06.13 15:49:35.065865 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:35.201855 [ 5110 ] {11adbb93-4064-4af4-8b8a-cc396e27e4fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 673, line 674) (in query: SELECT h3HexAreaKm2([], [], []);) 2025.06.13 15:49:35.210311 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:35.289786 [ 5110 ] {c5cc9d2b-a1f2-46ba-9e6f-a4fb241dc33f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 674, line 675) (in query: SELECT h3HexAreaM2([], [], []);) 2025.06.13 15:49:35.302706 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:35.391077 [ 5110 ] {1f64e200-6673-4baf-be49-16089b7b0750} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 675, line 676) (in query: SELECT h3HexRing([], [], []);) 2025.06.13 15:49:35.402874 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:35.466650 [ 5110 ] {e6555c02-022b-42e6-b08e-4779ef62685c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 676, line 677) (in query: SELECT h3IndexesAreNeighbors([], [], []);) 2025.06.13 15:49:35.474579 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:35.562203 [ 5110 ] {6f3dbbfa-dcfa-4cef-9d5e-7965889b82a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 677, line 678) (in query: SELECT h3IsPentagon([], [], []);) 2025.06.13 15:49:35.574286 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:35.626499 [ 5110 ] {bd88721f-f8ca-4889-850e-a22d26650e73} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 678, line 679) (in query: SELECT h3IsResClassIII([], [], []);) 2025.06.13 15:49:35.632669 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:35.666337 [ 5110 ] {a26cfc1e-aa88-4130-8000-58a1035a9d09} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 679, line 680) (in query: SELECT h3IsValid([], [], []);) 2025.06.13 15:49:35.672720 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:35.728854 [ 5110 ] {ef408bf6-147b-4282-a892-4f29909f8a35} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 680, line 681) (in query: SELECT h3Line([], [], []);) 2025.06.13 15:49:35.739627 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:35.804999 [ 5110 ] {f68844d8-bab6-4554-bf9e-fcbafddff1af} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 681, line 682) (in query: SELECT h3NumHexagons([], [], []);) 2025.06.13 15:49:35.830672 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:35.940851 [ 5110 ] {5422d759-e81b-4506-9f75-15dc921888e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 682, line 683) (in query: SELECT h3PointDistKm([], [], []);) 2025.06.13 15:49:35.982442 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:36.040418 [ 5110 ] {767ad361-7707-4ac0-a6d1-7461187bbabc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 683, line 684) (in query: SELECT h3PointDistM([], [], []);) 2025.06.13 15:49:36.059869 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:36.139634 [ 5110 ] {8c702746-a480-423c-beee-7d16d38f3119} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 684, line 685) (in query: SELECT h3PointDistRads([], [], []);) 2025.06.13 15:49:36.151577 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:36.252777 [ 5110 ] {a080b89e-72cc-4ecb-8ec5-8a460f142241} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 685, line 686) (in query: SELECT h3ToCenterChild([], [], []);) 2025.06.13 15:49:36.261162 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:36.336723 [ 5110 ] {c5819fa7-6e27-4e5c-b80f-0b4e54ca33b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 686, line 687) (in query: SELECT h3ToChildren([], [], []);) 2025.06.13 15:49:36.345529 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:36.411015 [ 5110 ] {a0b3ea7f-3459-4e55-a23d-60c3274d80ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 687, line 688) (in query: SELECT h3ToGeo([], [], []);) 2025.06.13 15:49:36.419960 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:36.462696 [ 5110 ] {576d5747-af95-48a7-8657-25dd5457e3cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 688, line 689) (in query: SELECT h3ToGeoBoundary([], [], []);) 2025.06.13 15:49:36.490764 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:36.567700 [ 5110 ] {22614191-987f-4bfa-80a8-269929d8b74b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 689, line 690) (in query: SELECT h3ToParent([], [], []);) 2025.06.13 15:49:36.619654 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:36.666728 [ 5110 ] {65c3deb1-5e60-4038-b537-c9a5227d8736} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 690, line 691) (in query: SELECT h3ToString([], [], []);) 2025.06.13 15:49:36.674445 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:36.780318 [ 5110 ] {bcfa21d1-fe26-42f6-9132-a778d1d7b96f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 691, line 692) (in query: SELECT h3UnidirectionalEdgeIsValid([], [], []);) 2025.06.13 15:49:36.799156 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:36.966640 [ 5110 ] {e311d21d-6785-4d5f-a2f8-380e80af67c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 692, line 693) (in query: SELECT h3kRing([], [], []);) 2025.06.13 15:49:36.975934 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:37.047773 [ 18377 ] {d59087e3-69b7-4c7f-849e-c1c34c7dfd92} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60210.179886 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56296) (comment: 01079_order_by_pk.sql) (query 2, line 3) (in query: CREATE TABLE mt_pk ENGINE = MergeTree PARTITION BY d ORDER BY x SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 714781685, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 99, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 69597733, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 26947313, merge_max_block_size = 18593, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 6345272085, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3717157618, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 82, 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 = 94560, primary_key_compress_block_size = 54184, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true AS SELECT toDate(number % 32) AS d, number AS x FROM system.numbers LIMIT 10000010), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:49:37.104415 [ 34297 ] {9ea63724-d56d-456c-90c8-fa2276c50e5c} executeQuery: Code: 57. DB::Exception: Table test_3.mv already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46638) (comment: 03321_inner_materialized_view_nested.sql) (query 11, line 19) (in query: CREATE MATERIALIZED VIEW mv ORDER BY () AS SELECT x, arrayZip(y, z)::Nested(a int, b int) n FROM t;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:37.144351 [ 34297 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.mv already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:37.197495 [ 18377 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60210.179886 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:49:37.403453 [ 5110 ] {271064f7-8720-46db-b94b-b81c0cb0edbd} executeQuery: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 694, line 695) (in query: SELECT has([], [], []);) 2025.06.13 15:49:37.412799 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:37.540486 [ 5110 ] {458c8764-1f2b-4895-ace9-33548a6c69c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 695, line 696) (in query: SELECT hasAll([], [], []);) 2025.06.13 15:49:37.549332 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:37.594154 [ 5110 ] {8ba2abc2-3a93-41ab-8634-550265372f82} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 696, line 697) (in query: SELECT hasAny([], [], []);) 2025.06.13 15:49:37.621079 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:37.683627 [ 5110 ] {37072c8d-42a7-48d6-9a61-0ea6402f0830} executeQuery: Code: 43. DB::Exception: First argument for function hasColumnInTable must be const String.: In scope SELECT hasColumnInTable([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 697, line 698) (in query: SELECT hasColumnInTable([], [], []);) 2025.06.13 15:49:37.698987 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function hasColumnInTable must be const String.: In scope SELECT hasColumnInTable([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:37.783870 [ 5110 ] {dd2a9150-ae78-4853-baf6-6489ba8f946f} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 698, line 699) (in query: SELECT hasSubsequence([], [], []);) 2025.06.13 15:49:37.806167 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:37.928002 [ 5110 ] {30b9b1f0-b39c-4020-9e96-5fad1354870b} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 699, line 700) (in query: SELECT hasSubsequenceCaseInsensitive([], [], []);) 2025.06.13 15:49:37.945813 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:38.096500 [ 5110 ] {0bb37ce7-d0ee-4bd4-9d8d-e4b8e97efd23} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 700, line 701) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:49:38.110310 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:38.251660 [ 5110 ] {68475f19-7311-4cc5-a3f6-b38f9928ee10} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 701, line 702) (in query: SELECT hasSubsequenceUTF8([], [], []);) 2025.06.13 15:49:38.258905 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:38.342256 [ 5110 ] {86db19fd-451b-4a6d-bb71-95548ac015d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 702, line 703) (in query: SELECT hasSubstr([], [], []);) 2025.06.13 15:49:38.350516 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:38.530655 [ 5110 ] {d202c764-2685-4247-aab7-5db12ed00142} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 703, line 704) (in query: SELECT hasThreadFuzzer([], [], []);) 2025.06.13 15:49:38.541326 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:38.793736 [ 5110 ] {b3b8a9b6-0a1e-4a66-bb27-cea0009e8fbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 704, line 705) (in query: SELECT hasToken([], [], []);) 2025.06.13 15:49:38.800707 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:38.917161 [ 5110 ] {1a8201f4-a575-4acb-a528-5b5556d6d8f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 705, line 706) (in query: SELECT hasTokenCaseInsensitive([], [], []);) 2025.06.13 15:49:38.933715 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:39.139936 [ 5110 ] {2635217a-8c28-46a6-bd85-9266a6b4c75c} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 706, line 707) (in query: SELECT hasTokenCaseInsensitiveOrNull([], [], []);) 2025.06.13 15:49:39.146452 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:39.262974 [ 5110 ] {ae769270-690e-4a2d-bd8b-9fd5a5365af8} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 707, line 708) (in query: SELECT hasTokenOrNull([], [], []);) 2025.06.13 15:49:39.291034 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:39.450591 [ 5110 ] {ccd71928-7d11-4d48-b8d6-f5e7c2eb2195} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 708, line 709) (in query: SELECT hex([], [], []);) 2025.06.13 15:49:39.472684 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:39.602987 [ 5110 ] {bc960f2b-183a-417f-a5a9-735261b2daac} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 709, line 710) (in query: SELECT hilbertDecode([], [], []);) 2025.06.13 15:49:39.629992 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:39.704271 [ 5110 ] {bc616729-44ec-443f-8fae-8073cd2fa0f7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for function hilbertEncode, should be a native UInt: In scope SELECT hilbertEncode([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 710, line 711) (in query: SELECT hilbertEncode([], [], []);) 2025.06.13 15:49:39.712073 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for function hilbertEncode, should be a native UInt: In scope SELECT hilbertEncode([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:39.797466 [ 5110 ] {74150055-67b4-4b57-bd17-c99b5a67e6e7} executeQuery: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 711, line 712) (in query: SELECT histogram([], [], []);) 2025.06.13 15:49:39.809704 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:39.920897 [ 5110 ] {f259b511-cd85-4b5e-967f-f9f236f25d53} executeQuery: Code: 48. DB::Exception: Hive hash is not combineable for multiple arguments: In scope SELECT hiveHash([], [], []). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 712, line 713) (in query: SELECT hiveHash([], [], []);) 2025.06.13 15:49:39.930735 [ 5110 ] {} TCPHandler: Code: 48. DB::Exception: Hive hash is not combineable for multiple arguments: In scope SELECT hiveHash([], [], []). (NOT_IMPLEMENTED) 2025.06.13 15:49:40.095235 [ 5110 ] {c3bc1896-53f9-47c4-bd6e-1122c88b224b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hop. Should be a date with time: In scope SELECT hop([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 713, line 714) (in query: SELECT hop([], [], []);) 2025.06.13 15:49:40.138658 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hop. Should be a date with time: In scope SELECT hop([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:40.305727 [ 5110 ] {40cb46cb-00d3-482d-a8c6-e5b2b726af77} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hopEnd. Should be a date with time: In scope SELECT hopEnd([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 714, line 715) (in query: SELECT hopEnd([], [], []);) 2025.06.13 15:49:40.344516 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hopEnd. Should be a date with time: In scope SELECT hopEnd([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:40.588804 [ 5110 ] {b6d0c8b5-3251-49c0-a884-d40e9ce8716b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hopStart. Should be a date with time: In scope SELECT hopStart([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 715, line 716) (in query: SELECT hopStart([], [], []);) 2025.06.13 15:49:40.608262 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hopStart. Should be a date with time: In scope SELECT hopStart([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:40.703896 [ 5110 ] {2cf29652-5f8d-459a-86f2-7ddc583cff7d} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 716, line 717) (in query: SELECT hostName([], [], []);) 2025.06.13 15:49:40.736903 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:40.858418 [ 5110 ] {8c8ef8af-e46f-4ec3-9b50-dee9cce4b270} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 717, line 718) (in query: SELECT hostname([], [], []);) 2025.06.13 15:49:40.876223 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:40.993604 [ 5110 ] {105892b7-a8d7-49de-a7b8-6610bdde5d06} executeQuery: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 718, line 719) (in query: SELECT hypot([], [], []);) 2025.06.13 15:49:41.012803 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:41.185848 [ 5110 ] {7d075a81-be8e-45ac-b5b8-a870b5b2a169} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergBucket doesn't match: passed 3, should be 2: In scope SELECT icebergBucket([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 719, line 720) (in query: SELECT icebergBucket([], [], []);) 2025.06.13 15:49:41.227851 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergBucket doesn't match: passed 3, should be 2: In scope SELECT icebergBucket([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:41.439619 [ 5110 ] {fa32bcb8-0549-417c-93d1-102fe73d4ef1} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergHash doesn't match: passed 3, should be 1: In scope SELECT icebergHash([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 720, line 721) (in query: SELECT icebergHash([], [], []);) 2025.06.13 15:49:41.546401 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergHash doesn't match: passed 3, should be 1: In scope SELECT icebergHash([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:41.713221 [ 5110 ] {4515fd44-f6ca-471a-a007-489cf4033c49} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 3, should be 2: In scope SELECT icebergTruncate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 721, line 722) (in query: SELECT icebergTruncate([], [], []);) 2025.06.13 15:49:41.808571 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 3, should be 2: In scope SELECT icebergTruncate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:41.909401 [ 5110 ] {b8ddfbd4-f22d-4b44-87ce-42690ff84224} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 722, line 723) (in query: SELECT identity([], [], []);) 2025.06.13 15:49:41.934410 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:42.057701 [ 5110 ] {32867207-a326-4511-91f3-b8baf3edf8c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 723, line 724) (in query: SELECT idnaDecode([], [], []);) 2025.06.13 15:49:42.088493 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:42.343416 [ 5110 ] {43cdf280-880e-4168-a493-287b815725f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 724, line 725) (in query: SELECT idnaEncode([], [], []);) 2025.06.13 15:49:42.349892 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:42.437882 [ 5110 ] {c263c379-09e4-4241-9dec-8380037c815a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument (condition) of function if. Must be UInt8.: In scope SELECT if([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 725, line 726) (in query: SELECT if([], [], []);) 2025.06.13 15:49:42.445791 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument (condition) of function if. Must be UInt8.: In scope SELECT if([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:42.515732 [ 5110 ] {ecd88707-f968-4462-8243-ce826b98cfc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 726, line 727) (in query: SELECT ifNotFinite([], [], []);) 2025.06.13 15:49:42.524232 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:42.623986 [ 5110 ] {b4d63b71-f4db-421a-a610-b619cf7b9aef} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 727, line 728) (in query: SELECT ifNull([], [], []);) 2025.06.13 15:49:42.633799 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:43.031056 [ 5110 ] {d02fadc2-af86-41d5-811e-22daa8965eeb} executeQuery: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 729, line 730) (in query: SELECT ilike([], [], []);) 2025.06.13 15:49:43.043262 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:43.090563 [ 5110 ] {55943f07-b365-4042-8e07-a2de74e71722} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 730, line 731) (in query: SELECT in([], [], []);) 2025.06.13 15:49:43.095631 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:43.199051 [ 5110 ] {d5daabbb-5739-4430-ac51-4cfdccd5c067} executeQuery: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 731, line 732) (in query: SELECT inIgnoreSet([], [], []);) 2025.06.13 15:49:43.213835 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:43.608142 [ 5110 ] {4c5ee67f-ff66-41a9-a432-d3b1ec65130a} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 733, line 734) (in query: SELECT indexOf([], [], []);) 2025.06.13 15:49:43.625571 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:43.784458 [ 5110 ] {dbf9dadd-4f10-47b1-822e-4da573cc72e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 3, should be 2: In scope SELECT indexOfAssumeSorted([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 734, line 735) (in query: SELECT indexOfAssumeSorted([], [], []);) 2025.06.13 15:49:43.809053 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 3, should be 2: In scope SELECT indexOfAssumeSorted([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:43.859084 [ 5110 ] {442773d3-b8ef-42a4-bffe-d4ab3c6cc5e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 735, line 736) (in query: SELECT initcap([], [], []);) 2025.06.13 15:49:43.871648 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:43.910440 [ 5110 ] {679771b3-5f70-48e2-8b16-9065e8a362a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 736, line 737) (in query: SELECT initcapUTF8([], [], []);) 2025.06.13 15:49:43.917044 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:44.054610 [ 5110 ] {ec26baf5-8b18-4851-a1d5-dea32a316d59} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 737, line 738) (in query: SELECT initialQueryID([], [], []);) 2025.06.13 15:49:44.064372 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:44.128325 [ 5110 ] {d3dee695-de85-4efb-b355-08fe63e5e964} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initialQueryStartTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 738, line 739) (in query: SELECT initialQueryStartTime([], [], []);) 2025.06.13 15:49:44.148649 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initialQueryStartTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:44.285965 [ 5110 ] {e3b533d3-fc99-4142-bf6e-75cc70c83198} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 739, line 740) (in query: SELECT initial_query_id([], [], []);) 2025.06.13 15:49:44.296286 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:44.358066 [ 5110 ] {570f3071-3523-4ec6-9f86-d7d15cb234cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initial_query_start_time([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 740, line 741) (in query: SELECT initial_query_start_time([], [], []);) 2025.06.13 15:49:44.368629 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initial_query_start_time([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:44.420631 [ 5110 ] {b5eb0cd0-f862-4890-b7d1-e294078c5256} executeQuery: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 741, line 742) (in query: SELECT initializeAggregation([], [], []);) 2025.06.13 15:49:44.427082 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:44.494053 [ 5110 ] {a4a87ce2-6410-4694-a839-7f61999033ee} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionCaseInsensitive: In scope SELECT instr([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 742, line 743) (in query: SELECT instr([], [], []);) 2025.06.13 15:49:44.503866 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionCaseInsensitive: In scope SELECT instr([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:44.589916 [ 5110 ] {af08a42c-3401-4b82-b266-61e588084e7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 743, line 744) (in query: SELECT intDiv([], [], []);) 2025.06.13 15:49:44.601342 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:44.665706 [ 5110 ] {70843958-32a8-4bd5-b25f-72a9aa5f38c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 744, line 745) (in query: SELECT intDivOrZero([], [], []);) 2025.06.13 15:49:44.673664 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:44.733258 [ 5110 ] {11897994-feb3-43cb-b204-81e7ee820f3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 745, line 746) (in query: SELECT intExp10([], [], []);) 2025.06.13 15:49:44.746094 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:44.797335 [ 5110 ] {bb92cf85-9471-43b7-895e-2fbfabfd0b55} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 746, line 747) (in query: SELECT intExp2([], [], []);) 2025.06.13 15:49:44.801772 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:44.890050 [ 5110 ] {9a5663d8-408d-45d0-8432-08df197efe7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 747, line 748) (in query: SELECT intHash32([], [], []);) 2025.06.13 15:49:45.027881 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:45.107064 [ 5110 ] {dac28063-6a92-4db2-84ae-16519807bafd} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 748, line 749) (in query: SELECT intHash64([], [], []);) 2025.06.13 15:49:45.125310 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:45.271038 [ 5110 ] {a46ac543-6c74-4117-809b-c6bfd9a383f6} executeQuery: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 749, line 750) (in query: SELECT intervalLengthSum([], [], []);) 2025.06.13 15:49:45.283326 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:45.376919 [ 5110 ] {82eeddd9-d54a-440a-828e-45d5fb2982f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 750, line 751) (in query: SELECT isConstant([], [], []);) 2025.06.13 15:49:45.385614 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:45.460338 [ 5110 ] {9ceaa310-b1d5-48e4-9461-8c0cee45a0c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDecimalOverflow doesn't match: passed 3, should be 1 or 2.: In scope SELECT isDecimalOverflow([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 751, line 752) (in query: SELECT isDecimalOverflow([], [], []);) 2025.06.13 15:49:45.472328 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDecimalOverflow doesn't match: passed 3, should be 1 or 2.: In scope SELECT isDecimalOverflow([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:45.589220 [ 5110 ] {84d00c25-660c-4cbb-ab3c-94a7ef44e009} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 752, line 753) (in query: SELECT isDynamicElementInSharedData([], [], []);) 2025.06.13 15:49:45.610678 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:45.728303 [ 5110 ] {27911e6d-7d63-4815-90b2-a6771ec3c9d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 753, line 754) (in query: SELECT isFinite([], [], []);) 2025.06.13 15:49:45.756441 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:45.864187 [ 5110 ] {a0ce0030-60f9-4176-a237-43f31c6566b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 754, line 755) (in query: SELECT isIPAddressInRange([], [], []);) 2025.06.13 15:49:45.872606 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:45.933536 [ 5110 ] {51767d6d-e5a2-4646-ae83-682cb216b0aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 755, line 756) (in query: SELECT isIPv4String([], [], []);) 2025.06.13 15:49:45.944056 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:45.978162 [ 6236 ] {da854860-69ad-410e-9f7f-8b9c4c7cc64c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49638) (comment: 02867_null_lc_in_bug.sql) (in query: DROP DATABASE IF EXISTS test_s5tzuvyf SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:45.982983 [ 6236 ] {da854860-69ad-410e-9f7f-8b9c4c7cc64c} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:46.106196 [ 5110 ] {0f767994-3b10-42ea-94b7-0be1e3f105f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 756, line 757) (in query: SELECT isIPv6String([], [], []);) 2025.06.13 15:49:46.126575 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:46.237685 [ 5110 ] {71e3ea65-ab72-482f-9106-e57646e2d25e} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 757, line 758) (in query: SELECT isInfinite([], [], []);) 2025.06.13 15:49:46.261912 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:46.361039 [ 5110 ] {2750659b-ac84-4d3d-a1ab-948b2505f214} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 758, line 759) (in query: SELECT isNaN([], [], []);) 2025.06.13 15:49:46.375564 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:46.589377 [ 5110 ] {a06f1d8e-c13d-4291-b968-57257d5053fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 759, line 760) (in query: SELECT isNotDistinctFrom([], [], []);) 2025.06.13 15:49:46.603998 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:46.705136 [ 5110 ] {536c073a-1dc2-4ff8-9dc8-8c7472df92ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 760, line 761) (in query: SELECT isNotNull([], [], []);) 2025.06.13 15:49:46.725672 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:46.901943 [ 5110 ] {fd58a51c-c2bc-4e24-953b-a54523f83170} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 761, line 762) (in query: SELECT isNull([], [], []);) 2025.06.13 15:49:46.923482 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:47.107657 [ 5110 ] {0cb90254-acf0-4fb1-9732-19d54fabdcef} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 762, line 763) (in query: SELECT isNullable([], [], []);) 2025.06.13 15:49:47.126597 [ 34313 ] {34158034-931f-47ba-9d97-65476e3d2b43} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60036.816419 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58676) (comment: 02521_aggregation_by_partitions.sql) (query 29, line 57) (in query: select throwIf(count() != 4) from remote('127.0.0.{1,2}', currentDatabase(), t3) group by a format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:49:47.222008 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:47.248276 [ 2860 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:35734, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:47.249642 [ 2860 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:35734, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:47.286950 [ 34313 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60036.816419 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:49:47.426805 [ 5110 ] {705dc2c3-f33d-4121-a0cb-fa0210745298} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 763, line 764) (in query: SELECT isValidJSON([], [], []);) 2025.06.13 15:49:47.463301 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:47.607325 [ 5110 ] {02872f9c-430e-4f86-a0c0-593c9fd118b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 764, line 765) (in query: SELECT isValidUTF8([], [], []);) 2025.06.13 15:49:47.631950 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:47.848182 [ 5110 ] {78d37891-05a1-4719-8f80-f46ad7010047} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 765, line 766) (in query: SELECT isZeroOrNull([], [], []);) 2025.06.13 15:49:47.886230 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:48.006716 [ 5110 ] {34a190e2-6453-4bd4-b346-5e5a61e86c0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 766, line 767) (in query: SELECT jaroSimilarity([], [], []);) 2025.06.13 15:49:48.023315 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:48.127291 [ 5110 ] {4cea6367-d8c7-4047-aa68-0c946ec10460} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 767, line 768) (in query: SELECT jaroWinklerSimilarity([], [], []);) 2025.06.13 15:49:48.146708 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:48.363963 [ 5110 ] {be0a8fc8-0418-4bcc-b792-084340af9687} executeQuery: Code: 48. DB::Exception: Java hash is not combineable for multiple arguments: In scope SELECT javaHash([], [], []). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 768, line 769) (in query: SELECT javaHash([], [], []);) 2025.06.13 15:49:48.396919 [ 5110 ] {} TCPHandler: Code: 48. DB::Exception: Java hash is not combineable for multiple arguments: In scope SELECT javaHash([], [], []). (NOT_IMPLEMENTED) 2025.06.13 15:49:48.528737 [ 5110 ] {4baa66f8-80ee-4052-b2da-2db4f766dc13} executeQuery: Code: 48. DB::Exception: Java hash is not combineable for multiple arguments: In scope SELECT javaHashUTF16LE([], [], []). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 769, line 770) (in query: SELECT javaHashUTF16LE([], [], []);) 2025.06.13 15:49:48.553796 [ 5110 ] {} TCPHandler: Code: 48. DB::Exception: Java hash is not combineable for multiple arguments: In scope SELECT javaHashUTF16LE([], [], []). (NOT_IMPLEMENTED) 2025.06.13 15:49:48.744153 [ 5110 ] {24409904-a02a-45d8-9f50-436a7972c2d7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 770, line 771) (in query: SELECT joinGet([], [], []);) 2025.06.13 15:49:48.762019 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:48.946551 [ 5110 ] {b43cb30a-b172-4e29-b612-812837ecb07b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 771, line 772) (in query: SELECT joinGetOrNull([], [], []);) 2025.06.13 15:49:49.020353 [ 4163 ] {0c2a87a3-c6e1-46a1-a5f6-5995fd08a3b1} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 3.89 MiB (attempt to allocate chunk of 3.89 MiB), maximum: 9.31 GiB: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:41030) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 3500000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc3b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffa4627 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x000000003224ef9c 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 20. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 21. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:49:49.032524 [ 4163 ] {0c2a87a3-c6e1-46a1-a5f6-5995fd08a3b1} DynamicQueryHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 3.89 MiB (attempt to allocate chunk of 3.89 MiB), maximum: 9.31 GiB: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc3b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffa4627 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x000000003224ef9c 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 20. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 21. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:49.050963 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:49.221998 [ 5110 ] {5e3456ab-a8cd-4236-a432-31e3dc904057} executeQuery: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT jsonMergePatch([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 772, line 773) (in query: SELECT jsonMergePatch([], [], []);) 2025.06.13 15:49:49.258383 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT jsonMergePatch([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:49.380478 [ 5110 ] {351b924b-91c5-448e-926a-87024241304e} executeQuery: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 773, line 774) (in query: SELECT jumpConsistentHash([], [], []);) 2025.06.13 15:49:49.388220 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:49.441435 [ 9636 ] {5117d5bf-40fc-4368-bc1c-8117949da797} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37850) (comment: 01870_modulo_partition_key.sql) (in query: DROP DATABASE IF EXISTS test_hftyb7hl SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:49.445626 [ 9636 ] {5117d5bf-40fc-4368-bc1c-8117949da797} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:49.589222 [ 8099 ] {add76163-c3b8-4466-815b-6d144a9ba967} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42582) (comment: 02803_remote_cannot_clone_block.sql) (query 3, line 9) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:49:49.627700 [ 8099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:49:49.666416 [ 6219 ] {90ca4590-cd53-4816-b208-feec306a4952} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49706) (comment: 01870_modulo_partition_key.sql) (in query: DROP DATABASE IF EXISTS test_hftyb7hl SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:49:49.672086 [ 6219 ] {90ca4590-cd53-4816-b208-feec306a4952} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:49.924342 [ 5110 ] {121decf4-686b-4da2-b4d8-a01c500d97d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 3, should be 1: In scope SELECT keccak256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 775, line 776) (in query: SELECT keccak256([], [], []);) 2025.06.13 15:49:49.938721 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 3, should be 1: In scope SELECT keccak256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:50.134175 [ 42495 ] {} test_hftyb7hl.table1 (b91b0a11-11e4-4d17-83b2-53252fb9cf5e): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.13 15:49:50.227255 [ 5110 ] {cade0b9c-c426-4cfa-b800-74e0d69927cf} executeQuery: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 776, line 777) (in query: SELECT kolmogorovSmirnovTest([], [], []);) 2025.06.13 15:49:50.241066 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:50.292590 [ 42495 ] {} DatabaseCatalog: Cannot drop table test_hftyb7hl.table1 (b91b0a11-11e4-4d17-83b2-53252fb9cf5e). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2942: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030cafe6a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2879: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000030caed0f 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3285: DB::MergeTreeData::dropAllData() @ 0x0000000030cbb267 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1365: DB::StorageReplicatedMergeTree::drop() @ 0x00000000305b2c12 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d5f99b1 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d607d44 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 15. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:50.354673 [ 5110 ] {2c9d9609-9d4b-4d4b-8092-12d512e5db2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 777, line 778) (in query: SELECT kostikConsistentHash([], [], []);) 2025.06.13 15:49:50.403908 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:51.136108 [ 5110 ] {2821f778-d084-4e91-9b3f-4f594cc2433b} executeQuery: Code: 42. DB::Exception: Aggregate function kurtPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 780, line 781) (in query: SELECT kurtPop([], [], []);) 2025.06.13 15:49:51.194151 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function kurtPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:51.468107 [ 5110 ] {24f22d1e-5495-40db-a5f9-8f756bb71566} executeQuery: Code: 42. DB::Exception: Aggregate function kurtSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 781, line 782) (in query: SELECT kurtSamp([], [], []);) 2025.06.13 15:49:51.488590 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function kurtSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:51.615991 [ 5110 ] {75861d82-21fa-4a66-8109-c1c4d4b31c2a} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 782, line 783) (in query: SELECT lagInFrame([], [], []);) 2025.06.13 15:49:51.648156 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nothing)' given. (BAD_ARGUMENTS) 2025.06.13 15:49:51.799052 [ 5110 ] {01da2284-16f5-43db-8556-3bc004e511cd} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 783, line 784) (in query: SELECT largestTriangleThreeBuckets([], [], []);) 2025.06.13 15:49:51.828100 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:51.946445 [ 5110 ] {964c9ffa-8b51-40e2-bae5-d4179e9fd1eb} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 784, line 785) (in query: SELECT lastValueRespectNulls([], [], []);) 2025.06.13 15:49:51.982422 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:52.099747 [ 5110 ] {7b4d3144-7db3-4615-bc20-f04193cc46f8} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 785, line 786) (in query: SELECT last_value([], [], []);) 2025.06.13 15:49:52.120482 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:52.299055 [ 5110 ] {8af1d657-7828-485b-a1ec-b77b87c6f51a} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 786, line 787) (in query: SELECT last_value_respect_nulls([], [], []);) 2025.06.13 15:49:52.307577 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:52.386573 [ 18511 ] {435e352d-93cb-41da-aa1c-d0ddff2cbd3c} executeQuery: Code: 60. DB::Exception: Table test_lwik40wo.data2 does not exist. Maybe you meant test_1.data?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:49746) (comment: 02895_peak_memory_usage_http_headers_regression.sh) (in query: DROP DATABASE IF EXISTS test_lwik40wo SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Storages/StorageMaterializedView.cpp:774: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000304d350e 9. ./src/Storages/StorageMaterializedView.h:37: DB::StorageMaterializedView::supportsTransactions() const @ 0x00000000304e268f 10. ./build_docker/./src/Interpreters/IInterpreter.cpp:44: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc4fcf5 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:49:52.393169 [ 18511 ] {435e352d-93cb-41da-aa1c-d0ddff2cbd3c} DynamicQueryHandler: Code: 60. DB::Exception: Table test_lwik40wo.data2 does not exist. Maybe you meant test_1.data?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Storages/StorageMaterializedView.cpp:774: DB::StorageMaterializedView::getTargetTable() const @ 0x00000000304d350e 9. ./src/Storages/StorageMaterializedView.h:37: DB::StorageMaterializedView::supportsTransactions() const @ 0x00000000304e268f 10. ./build_docker/./src/Interpreters/IInterpreter.cpp:44: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc4fcf5 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:52.425689 [ 5110 ] {60bc669f-d7ec-49cd-89c4-76ba53d8cccf} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 787, line 788) (in query: SELECT lcase([], [], []);) 2025.06.13 15:49:52.445609 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:52.556283 [ 5110 ] {62810a00-d75d-4ab1-9a1e-ddbe2ed0d501} executeQuery: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 788, line 789) (in query: SELECT lcm([], [], []);) 2025.06.13 15:49:52.578388 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:52.704830 [ 5110 ] {7b8a4412-7479-4d22-ad66-6a27dbe8e5a6} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 789, line 790) (in query: SELECT leadInFrame([], [], []);) 2025.06.13 15:49:52.742809 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nothing)' given. (BAD_ARGUMENTS) 2025.06.13 15:49:53.173260 [ 5110 ] {3fe34ad7-4c71-4a24-8910-dc873f4244f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 791, line 792) (in query: SELECT left([], [], []);) 2025.06.13 15:49:53.192497 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:53.398568 [ 5110 ] {b8c32d27-631b-4e56-8bc1-73000e1a106e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function leftPad, should be string: In scope SELECT leftPad([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 792, line 793) (in query: SELECT leftPad([], [], []);) 2025.06.13 15:49:53.420943 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function leftPad, should be string: In scope SELECT leftPad([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:53.522879 [ 5110 ] {4e7172a4-3269-4077-aeb3-22b5c3a590cb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function leftPadUTF8, should be string: In scope SELECT leftPadUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 793, line 794) (in query: SELECT leftPadUTF8([], [], []);) 2025.06.13 15:49:53.564632 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function leftPadUTF8, should be string: In scope SELECT leftPadUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:53.722134 [ 5110 ] {dc36f419-927b-4deb-9bff-75d941bd5a19} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 794, line 795) (in query: SELECT leftUTF8([], [], []);) 2025.06.13 15:49:53.751934 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:53.817868 [ 5110 ] {2e401424-ec18-43c4-b968-001cd9645bf9} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 795, line 796) (in query: SELECT lemmatize([], [], []);) 2025.06.13 15:49:53.826918 [ 5110 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:49:53.910847 [ 5110 ] {fdaa07ee-0667-4bb8-b323-615040551fc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 796, line 797) (in query: SELECT length([], [], []);) 2025.06.13 15:49:53.937233 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:54.051725 [ 5110 ] {da68c02e-8596-408f-bc39-161f57fa7baf} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 797, line 798) (in query: SELECT lengthUTF8([], [], []);) 2025.06.13 15:49:54.059554 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:54.166842 [ 5110 ] {3a37ebc9-426e-464d-ba11-aa170b066d28} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 798, line 799) (in query: SELECT less([], [], []);) 2025.06.13 15:49:54.178961 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:54.231636 [ 9642 ] {5ec33df1-5d25-43f7-9f5e-c8517f47e30b} executeQuery: Code: 57. DB::Exception: Table test_ydv6fbca.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 03210_json_type_alter_add_column.gen.sql) (in query: /* ddl_entry=query-0000000005 */ CREATE TABLE test_ydv6fbca.test UUID '5c231df9-d070-4f34-aabc-88f23326abea' (`x` UInt64) ENGINE = MergeTree ORDER BY x SETTINGS min_rows_for_wide_part = 100000000, min_bytes_for_wide_part = 1000000000, index_granularity = 8507, 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 = 492535923, compact_parts_max_granules_to_buffer = 110, compact_parts_merge_max_bytes_to_prefetch_part = 5983767, merge_max_block_size = 19076, old_parts_lifetime = 379., 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 = 21156988, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 33274, primary_key_compress_block_size = 32864, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:49:54.254022 [ 5110 ] {7f52d7c7-b9de-4d88-ad1a-7f88feadf048} executeQuery: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 799, line 800) (in query: SELECT lessOrEquals([], [], []);) 2025.06.13 15:49:54.272682 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:54.358254 [ 9642 ] {5ec33df1-5d25-43f7-9f5e-c8517f47e30b} executeQuery: Code: 57. DB::Exception: Table test_ydv6fbca.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42566) (comment: 03210_json_type_alter_add_column.gen.sql) (query 21, line 30) (in query: CREATE TABLE test (`x` UInt64) ENGINE = MergeTree ORDER BY x SETTINGS min_rows_for_wide_part = 100000000, min_bytes_for_wide_part = 1000000000, index_granularity = 8507, 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 = 492535923, compact_parts_max_granules_to_buffer = 110, compact_parts_merge_max_bytes_to_prefetch_part = 5983767, merge_max_block_size = 19076, old_parts_lifetime = 379., 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 = 21156988, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 33274, primary_key_compress_block_size = 32864, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:49:54.374413 [ 9642 ] {} TCPHandler: Code: 57. DB::Exception: Table test_ydv6fbca.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:49:54.425687 [ 5110 ] {73bf45b1-d129-4ec9-b200-c2b60db3ebd0} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 800, line 801) (in query: SELECT levenshteinDistance([], [], []);) 2025.06.13 15:49:54.443524 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:54.570799 [ 5110 ] {7671c6a9-1c0e-419b-9494-f53ec160c936} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 801, line 802) (in query: SELECT levenshteinDistanceUTF8([], [], []);) 2025.06.13 15:49:54.600686 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:54.742074 [ 5110 ] {bc6fb0e5-f637-4543-8607-947c78a7de8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 802, line 803) (in query: SELECT lgamma([], [], []);) 2025.06.13 15:49:54.768674 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:54.849451 [ 5110 ] {a4c3f88d-07f4-413c-9c0a-9b3753ff8138} executeQuery: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 803, line 804) (in query: SELECT like([], [], []);) 2025.06.13 15:49:54.888947 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:54.996649 [ 5110 ] {63010457-e40c-4525-b0b5-313ed17d463b} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 804, line 805) (in query: SELECT ln([], [], []);) 2025.06.13 15:49:55.019394 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:55.145315 [ 5110 ] {94cbeeb3-656b-4918-a7e1-adf969524b54} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function locate: In scope SELECT locate([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 805, line 806) (in query: SELECT locate([], [], []);) 2025.06.13 15:49:55.166231 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function locate: In scope SELECT locate([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:55.321494 [ 5110 ] {a5b4b885-2ee6-4e05-bcb0-8ab293955788} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 806, line 807) (in query: SELECT log([], [], []);) 2025.06.13 15:49:55.351673 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:55.408501 [ 3838 ] {2ae9111f-23d1-4787-93c1-cabac08cccf0} executeQuery: Code: 48. DB::Exception: Table engine Join supports only DELETE mutations. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42670) (comment: 01821_join_table_mutation.sql) (query 12, line 23) (in query: ALTER TABLE join_table_mutation UPDATE name = 'some' WHERE 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:175: DB::StorageJoin::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x0000000030438cb5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc415b6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:55.420190 [ 3838 ] {} TCPHandler: Code: 48. DB::Exception: Table engine Join supports only DELETE mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageJoin.cpp:175: DB::StorageJoin::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x0000000030438cb5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc415b6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:49:55.492527 [ 5110 ] {82f8ef05-81d7-491a-9d3e-868ca149e433} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 807, line 808) (in query: SELECT log10([], [], []);) 2025.06.13 15:49:55.505157 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:55.718619 [ 5110 ] {0a669a78-8a9b-420e-946c-c6c22690acd6} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 808, line 809) (in query: SELECT log1p([], [], []);) 2025.06.13 15:49:55.723378 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:55.903678 [ 5110 ] {bf2eebd5-c5f5-47e4-afbe-68d864d4f3b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 809, line 810) (in query: SELECT log2([], [], []);) 2025.06.13 15:49:55.960624 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:56.148671 [ 5110 ] {70c45ead-a74e-4eca-8851-6b5d322fea0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 810, line 811) (in query: SELECT logTrace([], [], []);) 2025.06.13 15:49:56.184567 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:56.267957 [ 34302 ] {aa2fca90-7d1e-4696-9c7a-205a7d9eecd6} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 3.89 MiB (attempt to allocate chunk of 3.31 MiB), maximum: 9.31 GiB: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:57820) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1048576 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc3b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffa4627 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x000000003224ef9c 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 20. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 21. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:49:56.282295 [ 34302 ] {aa2fca90-7d1e-4696-9c7a-205a7d9eecd6} DynamicQueryHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 3.89 MiB (attempt to allocate chunk of 3.31 MiB), maximum: 9.31 GiB: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc3b14 10. ./src/Common/PODArray.h:112: DB::ColumnVector::ColumnVector(unsigned long) @ 0x000000002ffa4627 11. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x000000003224ef9c 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 18. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a9021 20. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 21. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 22. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:56.367598 [ 5110 ] {bd9772a7-5247-4f2b-9988-1a1f7002bf8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 811, line 812) (in query: SELECT lowCardinalityIndices([], [], []);) 2025.06.13 15:49:56.407396 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:56.544445 [ 5110 ] {65c4d801-1123-4f7d-b0e6-a1c5ee52536a} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 812, line 813) (in query: SELECT lowCardinalityKeys([], [], []);) 2025.06.13 15:49:56.592735 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:56.768588 [ 5110 ] {7cc3df50-7508-46f9-847e-db08db8abcf6} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 813, line 814) (in query: SELECT lower([], [], []);) 2025.06.13 15:49:56.785251 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:56.948305 [ 5110 ] {3a7b6151-df1d-44a3-b6f2-b71697759930} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 814, line 815) (in query: SELECT lowerUTF8([], [], []);) 2025.06.13 15:49:56.978642 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:57.073247 [ 5110 ] {23ba1991-4e91-413c-9aef-10e13fc23ad0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function leftPad, should be string: In scope SELECT lpad([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 815, line 816) (in query: SELECT lpad([], [], []);) 2025.06.13 15:49:57.101176 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function leftPad, should be string: In scope SELECT lpad([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:57.279459 [ 5110 ] {321af086-f7f3-408a-936a-b8f5b8f68054} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 816, line 818) (in query: SELECT lttb([], [], []);) 2025.06.13 15:49:57.304087 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:57.469684 [ 34312 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:49:57.578564 [ 5110 ] {d68a07b2-a881-4057-8675-3291981d7179} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Array(Nothing): In scope SELECT makeDate([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 817, line 819) (in query: SELECT makeDate([], [], []);) 2025.06.13 15:49:57.600155 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Array(Nothing): In scope SELECT makeDate([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:57.716639 [ 5110 ] {a8d0a88e-51c7-438a-87ef-9e62281e7108} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Array(Nothing): In scope SELECT makeDate32([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 818, line 820) (in query: SELECT makeDate32([], [], []);) 2025.06.13 15:49:57.746477 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Array(Nothing): In scope SELECT makeDate32([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:57.865373 [ 5110 ] {8939efce-d8b7-4459-ab27-4828578c76b7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 3 arguments: In scope SELECT makeDateTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 819, line 821) (in query: SELECT makeDateTime([], [], []);) 2025.06.13 15:49:57.878526 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 3 arguments: In scope SELECT makeDateTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:57.998797 [ 5110 ] {98bcae10-a57c-46a1-b81e-038be677266e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 3 arguments: In scope SELECT makeDateTime64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 820, line 822) (in query: SELECT makeDateTime64([], [], []);) 2025.06.13 15:49:58.070125 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 3 arguments: In scope SELECT makeDateTime64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:58.123702 [ 5110 ] {bd4405a8-2901-4043-83a4-5983118e0a10} executeQuery: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 821, line 823) (in query: SELECT mannWhitneyUTest([], [], []);) 2025.06.13 15:49:58.152959 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:58.290640 [ 5110 ] {69035dcb-3311-49c0-a228-54f8587c7d8a} executeQuery: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 822, line 824) (in query: SELECT map([], [], []);) 2025.06.13 15:49:58.345406 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:58.527009 [ 5110 ] {23ef3cc5-a2eb-49ac-b411-df84c399fa09} executeQuery: Code: 43. DB::Exception: mapAdd only accepts maps: In scope SELECT mapAdd([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 823, line 825) (in query: SELECT mapAdd([], [], []);) 2025.06.13 15:49:58.552692 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: mapAdd only accepts maps: In scope SELECT mapAdd([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:58.681133 [ 5110 ] {82c19660-269d-42c5-a30a-0aa0cadbc45c} executeQuery: Code: 43. DB::Exception: Function mapAll requires at least one argument of type Map: In scope SELECT mapAll([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 824, line 826) (in query: SELECT mapAll([], [], []);) 2025.06.13 15:49:58.718306 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Function mapAll requires at least one argument of type Map: In scope SELECT mapAll([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:58.880006 [ 5110 ] {ef19b8c7-91cc-47eb-9a86-f637ab02e06b} executeQuery: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map: In scope SELECT mapApply([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 825, line 827) (in query: SELECT mapApply([], [], []);) 2025.06.13 15:49:58.898498 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map: In scope SELECT mapApply([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:59.017256 [ 5110 ] {02d99b05-e693-4c89-a3a0-8408640acf55} executeQuery: Code: 43. DB::Exception: Function mapConcat requires at least one argument of type Map: In scope SELECT mapConcat([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 826, line 828) (in query: SELECT mapConcat([], [], []);) 2025.06.13 15:49:59.032248 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Function mapConcat requires at least one argument of type Map: In scope SELECT mapConcat([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:59.210339 [ 5110 ] {be78f70c-6170-45b6-a9a2-2519e9306ed1} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 827, line 829) (in query: SELECT mapContains([], [], []);) 2025.06.13 15:49:59.233010 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:59.452599 [ 5110 ] {4d5d080e-e86d-4e33-8e0f-9df5d09efa67} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContainsKeyLike doesn't match: passed 3, should be 2: In scope SELECT mapContainsKeyLike([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 828, line 830) (in query: SELECT mapContainsKeyLike([], [], []);) 2025.06.13 15:49:59.550056 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContainsKeyLike doesn't match: passed 3, should be 2: In scope SELECT mapContainsKeyLike([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:49:59.640685 [ 34312 ] {c50bd87f-9af9-49a7-8017-a9f72ccbb3dd} 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.20286.altinityantalya (altinity build)) (from [::1]:47606) (query 1, line 1) (in query: SELECT throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:49:59.668730 [ 5110 ] {4a982d70-8289-4d4d-961e-1e1727a4c62f} executeQuery: Code: 43. DB::Exception: Function mapExists requires at least one argument of type Map: In scope SELECT mapExists([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 829, line 831) (in query: SELECT mapExists([], [], []);) 2025.06.13 15:49:59.669516 [ 34312 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:49:59.689370 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Function mapExists requires at least one argument of type Map: In scope SELECT mapExists([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:49:59.859277 [ 5110 ] {9e098e40-0916-471d-a27f-194b5f52471e} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapExtractKeyLike doesn't match: passed 3, should be 2: In scope SELECT mapExtractKeyLike([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 830, line 832) (in query: SELECT mapExtractKeyLike([], [], []);) 2025.06.13 15:49:59.877554 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapExtractKeyLike doesn't match: passed 3, should be 2: In scope SELECT mapExtractKeyLike([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:00.050025 [ 5110 ] {35e18bc4-90eb-4a12-a8bf-d17683135002} executeQuery: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map: In scope SELECT mapFilter([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 831, line 833) (in query: SELECT mapFilter([], [], []);) 2025.06.13 15:50:00.058241 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map: In scope SELECT mapFilter([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:00.076653 [ 4107 ] {0a6802f1-1e50-4cf1-a947-eef29ad09c05} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47618) (comment: 02803_remote_cannot_clone_block.sql) (query 3, line 9) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:50:00.128977 [ 4107 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:50:00.292756 [ 5110 ] {7c7a6b5e-1995-4a24-8ed1-d4efe9f2acfd} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 832, line 834) (in query: SELECT mapFromArrays([], [], []);) 2025.06.13 15:50:00.318702 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:00.464442 [ 5110 ] {bcdf8841-4478-44a9-91c3-67376af528e0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT mapFromString([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 833, line 835) (in query: SELECT mapFromString([], [], []);) 2025.06.13 15:50:00.505729 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT mapFromString([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:00.661820 [ 5110 ] {0b805545-c892-4956-ba67-5c5a29dc0a3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 834, line 836) (in query: SELECT mapKeys([], [], []);) 2025.06.13 15:50:00.697447 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:00.840262 [ 5110 ] {9267cc5e-4d18-4f7c-8c76-de11a10a58a3} executeQuery: Code: 43. DB::Exception: Function mapPartialReverseSort requires at least one argument of type Map: In scope SELECT mapPartialReverseSort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 835, line 837) (in query: SELECT mapPartialReverseSort([], [], []);) 2025.06.13 15:50:00.855874 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Function mapPartialReverseSort requires at least one argument of type Map: In scope SELECT mapPartialReverseSort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:00.965547 [ 3895 ] {d0308be6-a45c-42b4-b75c-2285027c5a96} 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.20286.altinityantalya (altinity build)) (from [::1]:47650) (query 1, line 1) (in query: SELECT throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:50:00.966364 [ 5110 ] {d9f76c0c-0a83-4859-a758-0ac6155f361a} executeQuery: Code: 43. DB::Exception: Function mapPartialSort requires at least one argument of type Map: In scope SELECT mapPartialSort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 836, line 838) (in query: SELECT mapPartialSort([], [], []);) 2025.06.13 15:50:00.991555 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Function mapPartialSort requires at least one argument of type Map: In scope SELECT mapPartialSort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:00.991976 [ 3895 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c15e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:50:01.126903 [ 5110 ] {153706f3-b3d2-4bef-a33d-993cfc122fe9} executeQuery: Code: 43. DB::Exception: Function mapPopulateSeries key argument should be of signed or unsigned integer type. Actual type Nothing: In scope SELECT mapPopulateSeries([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 837, line 839) (in query: SELECT mapPopulateSeries([], [], []);) 2025.06.13 15:50:01.149012 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Function mapPopulateSeries key argument should be of signed or unsigned integer type. Actual type Nothing: In scope SELECT mapPopulateSeries([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:01.164134 [ 3895 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:01.294907 [ 5110 ] {ac25b006-0f11-4533-bf15-469803b264e7} executeQuery: Code: 43. DB::Exception: Function mapReverseSort requires at least one argument of type Map: In scope SELECT mapReverseSort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 838, line 840) (in query: SELECT mapReverseSort([], [], []);) 2025.06.13 15:50:01.302656 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Function mapReverseSort requires at least one argument of type Map: In scope SELECT mapReverseSort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:01.360163 [ 5110 ] {c2eb1457-3fb2-42f1-a08c-6ba1add26cd3} executeQuery: Code: 43. DB::Exception: Function mapSort requires at least one argument of type Map: In scope SELECT mapSort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 839, line 841) (in query: SELECT mapSort([], [], []);) 2025.06.13 15:50:01.388419 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Function mapSort requires at least one argument of type Map: In scope SELECT mapSort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:01.442075 [ 5110 ] {d17eff58-1de3-4bbc-abd4-4e6213b1cf24} executeQuery: Code: 43. DB::Exception: mapSubtract only accepts maps: In scope SELECT mapSubtract([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 840, line 842) (in query: SELECT mapSubtract([], [], []);) 2025.06.13 15:50:01.447641 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: mapSubtract only accepts maps: In scope SELECT mapSubtract([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:01.589817 [ 5110 ] {fb1029ff-e2f2-4c92-a113-54d06b59fb30} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 841, line 843) (in query: SELECT mapUpdate([], [], []);) 2025.06.13 15:50:01.596531 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:01.656576 [ 5110 ] {9567fca8-3e41-4e93-a881-1046459fa375} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 842, line 844) (in query: SELECT mapValues([], [], []);) 2025.06.13 15:50:01.679145 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:01.891828 [ 5110 ] {68e86814-ca70-4352-b607-d457a41cee05} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 843, line 845) (in query: SELECT match([], [], []);) 2025.06.13 15:50:01.922909 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:01.977653 [ 5110 ] {f33a7792-a314-4818-b673-3da35c18fb3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 844, line 846) (in query: SELECT materialize([], [], []);) 2025.06.13 15:50:01.981812 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:02.015038 [ 5110 ] {52ff2d32-209b-4035-b5d5-193d088c65f7} executeQuery: Code: 42. DB::Exception: Aggregate function max requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 845, line 847) (in query: SELECT max([], [], []);) 2025.06.13 15:50:02.020673 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function max requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:02.048261 [ 5110 ] {5aab5f79-7b11-42a5-954b-7d4243fd710a} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 846, line 848) (in query: SELECT max2([], [], []);) 2025.06.13 15:50:02.057175 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:02.086997 [ 5110 ] {96e7ef2c-93f0-4044-b875-4d934dc24534} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 847, line 849) (in query: SELECT maxIntersections([], [], []);) 2025.06.13 15:50:02.092796 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:02.126932 [ 5110 ] {2a18803a-601d-4ba8-a77f-3e4464df15a5} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 848, line 850) (in query: SELECT maxIntersectionsPosition([], [], []);) 2025.06.13 15:50:02.135210 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:02.174683 [ 3982 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:50:02.199941 [ 3982 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:50:02.496697 [ 5110 ] {2b9e32c7-e69d-4f1d-99b1-a7c06ecf68b8} executeQuery: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 850, line 852) (in query: SELECT meanZTest([], [], []);) 2025.06.13 15:50:02.516275 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:02.556678 [ 5110 ] {881551bf-c5c4-400a-88c2-0be7eeb710d3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 851, line 853) (in query: SELECT median([], [], []);) 2025.06.13 15:50:02.624277 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:02.661069 [ 5110 ] {96f65a7b-259e-43de-a01f-45db3b774a50} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 852, line 854) (in query: SELECT medianBFloat16([], [], []);) 2025.06.13 15:50:02.669232 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:02.742705 [ 5110 ] {00e3cfba-a409-48f6-adec-e2de71345af2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 853, line 855) (in query: SELECT medianBFloat16Weighted([], [], []);) 2025.06.13 15:50:02.749466 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:02.815939 [ 5110 ] {34ce4d97-bb32-4c04-bcb0-188031120ada} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 854, line 856) (in query: SELECT medianDD([], [], []);) 2025.06.13 15:50:02.823061 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:02.861134 [ 5110 ] {a7966aff-f1fc-4ed8-9c5b-d7a3430efd11} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 855, line 857) (in query: SELECT medianDeterministic([], [], []);) 2025.06.13 15:50:02.868568 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:02.896744 [ 5110 ] {60d413c8-fee7-4808-86a9-d645730d3368} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 856, line 858) (in query: SELECT medianExact([], [], []);) 2025.06.13 15:50:02.900915 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:02.928276 [ 5110 ] {3386e043-f9dd-4654-88d2-4c1b05a705df} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 857, line 859) (in query: SELECT medianExactHigh([], [], []);) 2025.06.13 15:50:02.934706 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:02.972622 [ 5110 ] {b190d791-1bce-4188-bdbe-29847c4452eb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 858, line 860) (in query: SELECT medianExactLow([], [], []);) 2025.06.13 15:50:02.978542 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:03.128063 [ 5110 ] {0524ee7a-2a86-411c-9f2e-d00afa5484d7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 859, line 861) (in query: SELECT medianExactWeighted([], [], []);) 2025.06.13 15:50:03.135296 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:03.166455 [ 5110 ] {1d442134-e55f-4ee8-9fa6-77c3a7ff50d0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 860, line 862) (in query: SELECT medianExactWeightedInterpolated([], [], []);) 2025.06.13 15:50:03.177057 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:03.243901 [ 5110 ] {ca1afc17-a497-489f-82d2-0fdeba132e7c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 861, line 863) (in query: SELECT medianGK([], [], []);) 2025.06.13 15:50:03.250775 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:03.290707 [ 5110 ] {73b24318-4bac-4533-9aa0-6062c4a54582} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 862, line 864) (in query: SELECT medianInterpolatedWeighted([], [], []);) 2025.06.13 15:50:03.298133 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:03.332814 [ 5110 ] {c157748c-9625-491e-a317-9f111f8730f9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 863, line 865) (in query: SELECT medianTDigest([], [], []);) 2025.06.13 15:50:03.339183 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:03.380873 [ 5110 ] {9029be8f-7fc0-4e03-b2cb-96446bc9bbaa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 864, line 866) (in query: SELECT medianTDigestWeighted([], [], []);) 2025.06.13 15:50:03.401238 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:03.442825 [ 5110 ] {fce09f3e-6d90-44d6-8ebc-eccaef881703} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 865, line 867) (in query: SELECT medianTiming([], [], []);) 2025.06.13 15:50:03.447576 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:03.476198 [ 5110 ] {1888f92d-745f-49f9-bb35-9fc06b896538} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 866, line 868) (in query: SELECT medianTimingWeighted([], [], []);) 2025.06.13 15:50:03.481166 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:03.631748 [ 5110 ] {2ef378bb-ff1d-4840-be1a-93e19946d597} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT mid([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 868, line 870) (in query: SELECT mid([], [], []);) 2025.06.13 15:50:03.638570 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT mid([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:03.670479 [ 5110 ] {aca25819-1285-4762-a40e-c6f5869b97f9} executeQuery: Code: 42. DB::Exception: Aggregate function min requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 869, line 871) (in query: SELECT min([], [], []);) 2025.06.13 15:50:03.675811 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function min requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:03.706724 [ 5110 ] {2a308312-f070-431a-9acc-8d0fab620585} executeQuery: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 870, line 872) (in query: SELECT min2([], [], []);) 2025.06.13 15:50:03.718215 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:03.824378 [ 5110 ] {a0779424-46af-4ff6-80f8-605fc82d1b42} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 872, line 874) (in query: SELECT minSampleSizeContinous([], [], []);) 2025.06.13 15:50:03.829517 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:03.952762 [ 5110 ] {751e8e1f-a43b-46d8-a821-eda342c75dfd} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 873, line 875) (in query: SELECT minSampleSizeContinuous([], [], []);) 2025.06.13 15:50:03.968601 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:04.008742 [ 5110 ] {64b73173-e54f-4c6f-a788-ee4306757342} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 874, line 876) (in query: SELECT minSampleSizeConversion([], [], []);) 2025.06.13 15:50:04.014321 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:04.042199 [ 5110 ] {a30e3ce7-19df-4058-984c-f32112299abb} executeQuery: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 875, line 877) (in query: SELECT minus([], [], []);) 2025.06.13 15:50:04.047435 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:04.077931 [ 5110 ] {abf4b8a5-3a4f-4b40-bc3f-70bfd3afc51f} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 876, line 878) (in query: SELECT mismatches([], [], []);) 2025.06.13 15:50:04.085315 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:04.131864 [ 5110 ] {5a40736c-d2b0-4b57-923b-457ee3e21cbc} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 877, line 879) (in query: SELECT mod([], [], []);) 2025.06.13 15:50:04.138242 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:04.165295 [ 5110 ] {559e7317-e763-4070-8829-07efaa4ce8bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 878, line 880) (in query: SELECT modulo([], [], []);) 2025.06.13 15:50:04.174778 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:04.205095 [ 5110 ] {04a48d53-28db-467b-a241-930c9f3cde3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 879, line 881) (in query: SELECT moduloLegacy([], [], []);) 2025.06.13 15:50:04.212600 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:04.251655 [ 5110 ] {a8bd9a9b-ba78-4828-9524-16dc1f2395b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 880, line 882) (in query: SELECT moduloOrZero([], [], []);) 2025.06.13 15:50:04.258214 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:04.347813 [ 5110 ] {2e4bcdfb-5d26-4ed8-bef1-9199a2e1e3bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 881, line 883) (in query: SELECT monthName([], [], []);) 2025.06.13 15:50:04.359450 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:04.397554 [ 5110 ] {43f053c5-6c26-4526-b9f1-424c1348ee93} executeQuery: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 882, line 884) (in query: SELECT mortonDecode([], [], []);) 2025.06.13 15:50:04.405635 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:04.439436 [ 5110 ] {4e0c1576-6335-4d53-b8d9-2abe3c610175} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for function mortonEncode, should be a native UInt: In scope SELECT mortonEncode([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 883, line 885) (in query: SELECT mortonEncode([], [], []);) 2025.06.13 15:50:04.446161 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for function mortonEncode, should be a native UInt: In scope SELECT mortonEncode([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:04.559783 [ 5110 ] {291a6520-b274-47db-a719-8902ffb55dcd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiFuzzyMatchAllIndices: In scope SELECT multiFuzzyMatchAllIndices([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 884, line 886) (in query: SELECT multiFuzzyMatchAllIndices([], [], []);) 2025.06.13 15:50:04.566650 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiFuzzyMatchAllIndices: In scope SELECT multiFuzzyMatchAllIndices([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:04.609433 [ 5110 ] {8e706510-c8f6-4101-b9e4-3d21e7d91ac3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiFuzzyMatchAny: In scope SELECT multiFuzzyMatchAny([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 885, line 887) (in query: SELECT multiFuzzyMatchAny([], [], []);) 2025.06.13 15:50:04.615303 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiFuzzyMatchAny: In scope SELECT multiFuzzyMatchAny([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:04.658260 [ 5110 ] {1369e16b-e53d-4f27-93c7-fe6a13507580} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiFuzzyMatchAnyIndex: In scope SELECT multiFuzzyMatchAnyIndex([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 886, line 888) (in query: SELECT multiFuzzyMatchAnyIndex([], [], []);) 2025.06.13 15:50:04.665103 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiFuzzyMatchAnyIndex: In scope SELECT multiFuzzyMatchAnyIndex([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:04.710184 [ 5110 ] {33e30854-d237-44a7-aae3-76cf7e456de2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT multiIf([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 887, line 889) (in query: SELECT multiIf([], [], []);) 2025.06.13 15:50:04.721379 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT multiIf([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:04.831815 [ 5110 ] {68f2f6e7-f5d8-4f7c-bf72-b3788afe6f09} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 888, line 890) (in query: SELECT multiMatchAllIndices([], [], []);) 2025.06.13 15:50:04.844476 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:04.889129 [ 5110 ] {0256a6df-372a-42d8-84cc-63555e789132} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 889, line 891) (in query: SELECT multiMatchAny([], [], []);) 2025.06.13 15:50:04.896627 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:04.983595 [ 5110 ] {0b8cc645-6a9c-4703-b678-9a9ed103029b} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 890, line 892) (in query: SELECT multiMatchAnyIndex([], [], []);) 2025.06.13 15:50:04.997153 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:05.054227 [ 5110 ] {8cbd5b6a-c4f1-43e1-9e3a-d7f692c34c9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 891, line 893) (in query: SELECT multiSearchAllPositions([], [], []);) 2025.06.13 15:50:05.063121 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:05.133755 [ 5110 ] {0a23343e-b9c9-4d1b-9f36-c273e7e31ec8} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 892, line 894) (in query: SELECT multiSearchAllPositionsCaseInsensitive([], [], []);) 2025.06.13 15:50:05.154836 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:05.255332 [ 5110 ] {e1f5a256-34c9-4e54-aa9a-e91b5afb0f73} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 893, line 895) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:50:05.267605 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:05.330503 [ 5110 ] {93d99f6d-99d0-4df1-b318-2c0e68a21079} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 894, line 896) (in query: SELECT multiSearchAllPositionsUTF8([], [], []);) 2025.06.13 15:50:05.356099 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:05.448844 [ 5110 ] {1c708af6-3105-4a55-aa43-93e0790ac8e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 895, line 897) (in query: SELECT multiSearchAny([], [], []);) 2025.06.13 15:50:05.459864 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:05.570714 [ 5110 ] {7bdbae1a-cf9f-41b3-9d9b-84ffb6cf69f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 896, line 898) (in query: SELECT multiSearchAnyCaseInsensitive([], [], []);) 2025.06.13 15:50:05.578076 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:05.696866 [ 5110 ] {8cb0d4d6-1924-42b4-a26a-f2880eda4144} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 897, line 899) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:50:05.727593 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:05.798025 [ 5110 ] {74c768aa-bc41-471e-8d38-12bfd93c372b} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 898, line 900) (in query: SELECT multiSearchAnyUTF8([], [], []);) 2025.06.13 15:50:05.808669 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:05.947232 [ 5110 ] {f269b40f-9066-4cbc-b07f-0c8e95850ba1} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 899, line 901) (in query: SELECT multiSearchFirstIndex([], [], []);) 2025.06.13 15:50:05.960560 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:06.187965 [ 5110 ] {81321cd2-5327-4ad1-8abf-37857ed6f72a} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 900, line 902) (in query: SELECT multiSearchFirstIndexCaseInsensitive([], [], []);) 2025.06.13 15:50:06.246568 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:06.524622 [ 5110 ] {c5dae0ac-70c0-4a34-a1e1-64bd7d5ac178} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 901, line 903) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:50:06.535681 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:06.693299 [ 5110 ] {b019a3fe-b923-4a4b-bf55-e24b251bca51} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 902, line 904) (in query: SELECT multiSearchFirstIndexUTF8([], [], []);) 2025.06.13 15:50:06.743326 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:06.934245 [ 5110 ] {0c3b0cbf-08ee-4b5f-86fd-1d67b9362fd0} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 903, line 905) (in query: SELECT multiSearchFirstPosition([], [], []);) 2025.06.13 15:50:07.039920 [ 4172 ] {6429e9e8-2e6e-41e8-b2cc-8baedb1cc6ac} 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.20286.altinityantalya (altinity build)) (from [::1]:46144) (comment: 01139_asof_join_types.sql) (query 1, line 1) (in query: select * from (select 0 as k, toInt8(1) as v) t1 asof join (select 0 as k, toInt8(0) as v) t2 using(k, v);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf4487 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213d4c9 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:50:07.047016 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:07.107973 [ 4172 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf4487 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213d4c9 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:50:07.243069 [ 5110 ] {02e2ad65-0506-462b-9b85-5aedc6952276} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 904, line 906) (in query: SELECT multiSearchFirstPositionCaseInsensitive([], [], []);) 2025.06.13 15:50:07.289942 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:07.488189 [ 5110 ] {ced9822b-f602-4e70-9e8f-c618d8938a18} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 905, line 907) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:50:07.528458 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:07.657370 [ 5110 ] {a14f6f0e-4bf0-4dd6-a864-8c4b8082521e} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 906, line 908) (in query: SELECT multiSearchFirstPositionUTF8([], [], []);) 2025.06.13 15:50:07.685319 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:07.848645 [ 5110 ] {73e6a8af-6d82-4ce6-82b4-50f700b79b7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 907, line 909) (in query: SELECT multiply([], [], []);) 2025.06.13 15:50:07.864549 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:08.037567 [ 5110 ] {428aa4fc-b0cf-42f5-bcbc-c5626e2ff4f0} executeQuery: Code: 43. DB::Exception: Arguments for multiplyDecimal function must be Decimal: In scope SELECT multiplyDecimal([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 908, line 910) (in query: SELECT multiplyDecimal([], [], []);) 2025.06.13 15:50:08.061589 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Arguments for multiplyDecimal function must be Decimal: In scope SELECT multiplyDecimal([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:08.697897 [ 34347 ] {9dae7f09-57b1-47d1-81b5-9164aeed4c03} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34180) (comment: 03038_recursive_cte_postgres_4.sql) (in query: DROP DATABASE IF EXISTS test_e31dytfe SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:50:08.702861 [ 34347 ] {9dae7f09-57b1-47d1-81b5-9164aeed4c03} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:09.322630 [ 5110 ] {3013ae60-b178-4527-aa18-f3ea30b6adf5} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 914, line 916) (in query: SELECT negate([], [], []);) 2025.06.13 15:50:09.328692 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:09.505001 [ 5110 ] {1913259f-94ba-42b7-b293-a3ac8c50ea80} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 915, line 917) (in query: SELECT neighbor([], [], []);) 2025.06.13 15:50:09.522113 [ 5110 ] {} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:50:09.661768 [ 5110 ] {4162bca2-d8af-46a8-ad6c-eb9caac04adf} executeQuery: Code: 36. DB::Exception: First argument for function nested must be constant column with array of strings: In scope SELECT nested([], [], []). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 916, line 918) (in query: SELECT nested([], [], []);) 2025.06.13 15:50:09.701864 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: First argument for function nested must be constant column with array of strings: In scope SELECT nested([], [], []). (BAD_ARGUMENTS) 2025.06.13 15:50:09.821907 [ 5110 ] {6bd75ad2-8cfc-4e11-9e9e-967716bd54b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 917, line 919) (in query: SELECT netloc([], [], []);) 2025.06.13 15:50:09.827969 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:09.958552 [ 5110 ] {34340128-6c2c-4fca-a914-ec99563d10ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 918, line 920) (in query: SELECT ngramDistance([], [], []);) 2025.06.13 15:50:09.966144 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:10.021271 [ 34347 ] {41499ebe-e991-4283-ba2a-329183f7a33f} executeQuery: Code: 6. DB::Exception: Cannot parse string 'f' as Int32: syntax error at begin of string. Note: there are toInt32OrZero and toInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while converting source column `'f'` to destination column s. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46186) (comment: 02047_client_exception.expect) (query 1, line 1) (in query: INSERT INTO test_02047 SELECT 'f'), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b0e9120 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b0e24c8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ba8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b042dbe 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b041c23 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 19. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 23. ./build_docker/./src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb0de8b 24. ./build_docker/./src/Interpreters/ActionsDAG.cpp:362: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002cb0ef7c 25. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1637: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002cb217e7 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dce0b04 27. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5edc 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:50:10.031842 [ 34347 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'f' as Int32: syntax error at begin of string. Note: there are toInt32OrZero and toInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while converting source column `'f'` to destination column s. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b0e9120 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b0e24c8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02ba8e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b042dbe 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b041c23 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 15. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002addf493 16. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 17. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 19. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 23. ./build_docker/./src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x000000002cb0de8b 24. ./build_docker/./src/Interpreters/ActionsDAG.cpp:362: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002cb0ef7c 25. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1637: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002cb217e7 26. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dce0b04 27. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5edc 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:50:10.082752 [ 5110 ] {15f2e771-e1ac-48c4-9b75-a5932b85014d} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 919, line 921) (in query: SELECT ngramDistanceCaseInsensitive([], [], []);) 2025.06.13 15:50:10.109229 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:10.113994 [ 4172 ] {78612de7-f21b-4e3f-acb9-0b7fa9c7ecab} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'input' to function 'encrypt'. Expected: plaintext, got: Array(Nullable(Int16)): In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46206) (comment: 01667_aes_args_check.sql) (query 1, line 4) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6a32f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:50:10.129204 [ 4172 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'input' to function 'encrypt'. Expected: plaintext, got: Array(Nullable(Int16)): In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6a32f1 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:50:10.196156 [ 5110 ] {cc9f0367-e4f8-496f-9c9e-38f6748a3d43} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 920, line 922) (in query: SELECT ngramDistanceCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:50:10.219763 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:10.409137 [ 5110 ] {58df5ef3-0b5c-4fa5-abab-1e4376ca5702} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 921, line 923) (in query: SELECT ngramDistanceUTF8([], [], []);) 2025.06.13 15:50:10.495284 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:10.637058 [ 5110 ] {99c53d39-fb6c-4659-aae1-2282f0d34217} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHash must be String, got Array(Nothing): In scope SELECT ngramMinHash([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 922, line 924) (in query: SELECT ngramMinHash([], [], []);) 2025.06.13 15:50:10.689511 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHash must be String, got Array(Nothing): In scope SELECT ngramMinHash([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:10.791262 [ 5110 ] {805b0bd2-cad9-42b4-8670-7c2598011174} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArg must be String, got Array(Nothing): In scope SELECT ngramMinHashArg([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 923, line 925) (in query: SELECT ngramMinHashArg([], [], []);) 2025.06.13 15:50:10.818451 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArg must be String, got Array(Nothing): In scope SELECT ngramMinHashArg([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:10.961530 [ 5110 ] {3cf73560-4fef-4b3d-89ff-c3ce576894ca} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramMinHashArgCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 924, line 926) (in query: SELECT ngramMinHashArgCaseInsensitive([], [], []);) 2025.06.13 15:50:10.980828 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramMinHashArgCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:11.209362 [ 5110 ] {3f4eb14d-0114-43a8-98de-d83174d15ff7} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashArgCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 925, line 927) (in query: SELECT ngramMinHashArgCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:50:11.239932 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashArgCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:11.388650 [ 5110 ] {92a464ef-66da-4bf6-b9fb-e2b133068710} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashArgUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 926, line 928) (in query: SELECT ngramMinHashArgUTF8([], [], []);) 2025.06.13 15:50:11.413642 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashArgUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:11.628106 [ 5110 ] {c8b1039b-d84a-45e7-8755-c3e1eb8cf554} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramMinHashCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 927, line 929) (in query: SELECT ngramMinHashCaseInsensitive([], [], []);) 2025.06.13 15:50:11.660753 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramMinHashCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:11.841124 [ 5110 ] {3ad451af-d7f2-42ff-8d8f-fd961f74a613} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 928, line 930) (in query: SELECT ngramMinHashCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:50:11.887677 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:12.060155 [ 5110 ] {10fb7c88-ce93-4a33-9de6-2cecf239d6e6} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 929, line 931) (in query: SELECT ngramMinHashUTF8([], [], []);) 2025.06.13 15:50:12.111066 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:12.309063 [ 5110 ] {009b5c8b-4195-456d-b9b9-e0fe096ca248} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 930, line 932) (in query: SELECT ngramSearch([], [], []);) 2025.06.13 15:50:12.350578 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:12.553794 [ 5110 ] {b7ff16d7-6971-4536-abd9-c2b2a285cb61} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 931, line 933) (in query: SELECT ngramSearchCaseInsensitive([], [], []);) 2025.06.13 15:50:12.597500 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:12.781691 [ 5110 ] {9ef49339-cda1-4ff3-9662-93bdc3df9bac} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 932, line 934) (in query: SELECT ngramSearchCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:50:12.813170 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:12.947299 [ 5110 ] {297f746f-80dd-4f7a-ba86-8a569527bbdc} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 933, line 935) (in query: SELECT ngramSearchUTF8([], [], []);) 2025.06.13 15:50:12.985451 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:13.236718 [ 5110 ] {91b4acb6-6099-4a13-a94f-421875082f0b} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHash must be String, got Array(Nothing): In scope SELECT ngramSimHash([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 934, line 936) (in query: SELECT ngramSimHash([], [], []);) 2025.06.13 15:50:13.280170 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHash must be String, got Array(Nothing): In scope SELECT ngramSimHash([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:13.487325 [ 5110 ] {f8b3d68d-8847-4576-b93b-d2d2b290936f} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramSimHashCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 935, line 937) (in query: SELECT ngramSimHashCaseInsensitive([], [], []);) 2025.06.13 15:50:13.522415 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramSimHashCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:13.800256 [ 5110 ] {9889f50f-60c3-4bf0-9d19-5c58c4a3d36b} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramSimHashCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 936, line 938) (in query: SELECT ngramSimHashCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:50:13.826257 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramSimHashCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:13.832535 [ 4172 ] {a7666e66-b300-4956-82e7-0157c23ecc90} 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.20286.altinityantalya (altinity build)) (from [::1]:46208) (comment: 03032_string_to_variant_cast.sql) (query 7, line 7) (in query: select CAST('42', 'Variant(Date)') as v, variantType(v);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x0000000023e893ef 5. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:1060: DB::SerializationVariant::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c6a945c 6. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 7. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 8. DB::detail::FunctionCast::createStringToVariantWrapper() const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002ad96b85 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002ad966e2 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:50:13.873340 [ 4172 ] {} TCPHandler: Code: 117. DB::Exception: Cannot parse text value of type Variant(Date) here: 42: In scope SELECT CAST('42', 'Variant(Date)') AS v, variantType(v). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x0000000023e893ef 5. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:1060: DB::SerializationVariant::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002c6a945c 6. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002ad95e43 7. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002ad945fd 8. DB::detail::FunctionCast::createStringToVariantWrapper() const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002ad96b85 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002ad966e2 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017ce9d4f 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 2025.06.13 15:50:14.016664 [ 5110 ] {15ef2d25-a89f-4cb3-aed9-4ff0d0b9eec5} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashUTF8 must be String, got Array(Nothing): In scope SELECT ngramSimHashUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 937, line 939) (in query: SELECT ngramSimHashUTF8([], [], []);) 2025.06.13 15:50:14.050681 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashUTF8 must be String, got Array(Nothing): In scope SELECT ngramSimHashUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:14.259006 [ 5110 ] {3c6880bb-abb8-4304-a1a6-9d18f0cbeca7} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 938, line 940) (in query: SELECT ngrams([], [], []);) 2025.06.13 15:50:14.298884 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:14.455512 [ 5110 ] {aab2e7b6-9763-4cc2-9ab2-9b1be010a2e5} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'Array(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 939, line 941) (in query: SELECT nonNegativeDerivative([], [], []);) 2025.06.13 15:50:14.548653 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'Array(Nothing)' given. (BAD_ARGUMENTS) 2025.06.13 15:50:14.700190 [ 5110 ] {e3a103a2-1028-4087-990e-34fd52ca6f5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 940, line 942) (in query: SELECT normL1([], [], []);) 2025.06.13 15:50:14.714424 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:14.834927 [ 5110 ] {b3805ffb-dd07-4784-85b0-7d7c4be6d969} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 941, line 943) (in query: SELECT normL2([], [], []);) 2025.06.13 15:50:14.856924 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:14.982696 [ 5110 ] {2a552bfb-0666-4822-8fa7-fa6b14ba8845} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 942, line 944) (in query: SELECT normL2Squared([], [], []);) 2025.06.13 15:50:14.992998 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:15.137446 [ 5110 ] {e31540bc-98fb-43e9-86df-1410aadaf4fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 943, line 945) (in query: SELECT normLinf([], [], []);) 2025.06.13 15:50:15.146201 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:15.244430 [ 5110 ] {4c5f5204-b00a-4037-8045-2f7d76007c49} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 944, line 946) (in query: SELECT normLp([], [], []);) 2025.06.13 15:50:15.258668 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:15.339194 [ 5110 ] {0a80c02e-3f21-4c80-a8aa-0729eae163b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 945, line 947) (in query: SELECT normalizeL1([], [], []);) 2025.06.13 15:50:15.353988 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:15.537463 [ 5110 ] {d01e5f9c-2d11-4bab-8d0f-65030b1bd199} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 946, line 948) (in query: SELECT normalizeL2([], [], []);) 2025.06.13 15:50:15.571483 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:15.723320 [ 5110 ] {d141b366-2015-4b6a-9902-2e4f5e07cc33} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 947, line 949) (in query: SELECT normalizeLinf([], [], []);) 2025.06.13 15:50:15.747729 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:15.964814 [ 5110 ] {cc37b794-f12b-4c18-b9e0-427228da8b9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 948, line 950) (in query: SELECT normalizeLp([], [], []);) 2025.06.13 15:50:15.972535 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:16.201052 [ 5110 ] {01078552-5cd1-4f9d-b5eb-d243d101e64c} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 949, line 951) (in query: SELECT normalizeQuery([], [], []);) 2025.06.13 15:50:16.208833 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:16.352648 [ 5110 ] {133fc7c7-c1a7-4a96-a327-77dba2c593d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 950, line 952) (in query: SELECT normalizeQueryKeepNames([], [], []);) 2025.06.13 15:50:16.369758 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:16.550462 [ 5110 ] {53a7d06f-25a4-4aad-b659-dfa7216b3f26} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 951, line 953) (in query: SELECT normalizeUTF8NFC([], [], []);) 2025.06.13 15:50:16.558043 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:16.739754 [ 5110 ] {cbf4c6cc-ddd1-4889-807a-3ff963f19092} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 952, line 954) (in query: SELECT normalizeUTF8NFD([], [], []);) 2025.06.13 15:50:16.768330 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:16.964200 [ 5110 ] {ac6d42b3-cc0d-4e67-bcf0-dc0c68fa5adf} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 953, line 955) (in query: SELECT normalizeUTF8NFKC([], [], []);) 2025.06.13 15:50:17.009889 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:17.275228 [ 5110 ] {0b64f5d2-f23a-4dd5-b0f1-9661c82ed43a} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 954, line 956) (in query: SELECT normalizeUTF8NFKD([], [], []);) 2025.06.13 15:50:17.318294 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:17.549252 [ 5110 ] {cd7f5e1b-b63c-4426-b1f4-e3216147c547} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 955, line 957) (in query: SELECT normalizedQueryHash([], [], []);) 2025.06.13 15:50:17.566069 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:17.804024 [ 34347 ] {ae1e23ca-53da-4480-85a9-42eeca1d58cd} executeQuery: Code: 57. DB::Exception: Table test_rpumcjeu.runningConcurrency_test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45988) (comment: 01602_runningConcurrency.sql) (query 9, line 16) (in query: CREATE TABLE runningConcurrency_test(begin DateTime, end DateTime) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:50:17.832109 [ 34347 ] {} TCPHandler: Code: 57. DB::Exception: Table test_rpumcjeu.runningConcurrency_test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:50:17.861666 [ 5110 ] {6daa0f82-85cf-4000-8bcb-a6d5b94d37b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 956, line 958) (in query: SELECT normalizedQueryHashKeepNames([], [], []);) 2025.06.13 15:50:17.897287 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:17.972135 [ 5110 ] {ab113e58-05df-4d5d-86d9-3186b3d09aed} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 957, line 959) (in query: SELECT not([], [], []);) 2025.06.13 15:50:18.008978 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:18.201278 [ 5110 ] {07a05d82-2df8-4e32-a61c-276c796fce9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 958, line 960) (in query: SELECT notEmpty([], [], []);) 2025.06.13 15:50:18.208131 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:18.376892 [ 5110 ] {efab311c-4131-4a69-b080-85411abb4747} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 959, line 961) (in query: SELECT notEquals([], [], []);) 2025.06.13 15:50:18.388767 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:18.512192 [ 5110 ] {9249d595-8de2-43a1-8a22-9e0ce0305f12} executeQuery: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 960, line 962) (in query: SELECT notILike([], [], []);) 2025.06.13 15:50:18.625740 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:18.718998 [ 5110 ] {ca106c3f-9d76-4f65-b5b7-9b1b515c67d8} executeQuery: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 961, line 963) (in query: SELECT notIn([], [], []);) 2025.06.13 15:50:18.730559 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:18.899374 [ 5110 ] {77ac4b68-b480-4522-998b-5247fd52c366} executeQuery: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 962, line 964) (in query: SELECT notInIgnoreSet([], [], []);) 2025.06.13 15:50:18.932047 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:19.035840 [ 5110 ] {4f1c1d49-abcd-4d47-9037-e54eaeebaa07} executeQuery: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 963, line 965) (in query: SELECT notLike([], [], []);) 2025.06.13 15:50:19.054479 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:19.155373 [ 5110 ] {81f871d3-dd20-40c6-9f57-6e4ffd19f802} executeQuery: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 964, line 966) (in query: SELECT notNullIn([], [], []);) 2025.06.13 15:50:19.171568 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:19.334821 [ 5110 ] {18d430e1-116d-4c68-8967-4d83e7507c39} executeQuery: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 965, line 967) (in query: SELECT notNullInIgnoreSet([], [], []);) 2025.06.13 15:50:19.361621 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:20.364772 [ 5110 ] {d4b7846b-8daf-45de-b155-8f1e3e660c1f} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 969, line 971) (in query: SELECT now([], [], []);) 2025.06.13 15:50:20.381537 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:20.501696 [ 5110 ] {6ae53304-d951-4886-8523-dad4399b45f5} executeQuery: Code: 34. DB::Exception: Arguments size of function now64 should be 0, or 1, or 2: In scope SELECT now64([], [], []). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 970, line 972) (in query: SELECT now64([], [], []);) 2025.06.13 15:50:20.520055 [ 5110 ] {} TCPHandler: Code: 34. DB::Exception: Arguments size of function now64 should be 0, or 1, or 2: In scope SELECT now64([], [], []). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:50:20.728181 [ 5110 ] {0d8a0696-73bc-4cfb-b7b8-9f124a235407} executeQuery: Code: 34. DB::Exception: Arguments size of function nowInBlock should be 0 or 1: In scope SELECT nowInBlock([], [], []). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 971, line 973) (in query: SELECT nowInBlock([], [], []);) 2025.06.13 15:50:20.752111 [ 5110 ] {} TCPHandler: Code: 34. DB::Exception: Arguments size of function nowInBlock should be 0 or 1: In scope SELECT nowInBlock([], [], []). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:50:20.959600 [ 5110 ] {75784771-de02-4ef2-b62e-f3ae4016afaf} executeQuery: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 972, line 974) (in query: SELECT nth_value([], [], []);) 2025.06.13 15:50:21.008344 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:21.210846 [ 5110 ] {d6f97377-655e-4326-a316-557d19a6087b} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 973, line 975) (in query: SELECT ntile([], [], []);) 2025.06.13 15:50:21.247932 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:21.372901 [ 5110 ] {95cf5775-1259-4044-97aa-1d774561aab1} executeQuery: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 974, line 976) (in query: SELECT nullIf([], [], []);) 2025.06.13 15:50:21.428532 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:21.679486 [ 5110 ] {476e9fc7-3d1b-4113-84b9-dc30f56ceab8} executeQuery: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 975, line 977) (in query: SELECT nullIn([], [], []);) 2025.06.13 15:50:21.691437 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:21.855169 [ 5110 ] {6f5fb2ea-ae36-4f1f-a7db-60723b8ba358} executeQuery: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 976, line 978) (in query: SELECT nullInIgnoreSet([], [], []);) 2025.06.13 15:50:21.865409 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:21.990676 [ 4107 ] {ee5dbe91-6fab-4725-9eb8-eb9147a354b4} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_zmookgdx.table_for_rename1 (1f35adba-c40f-4270-8870-35eb4ecb9a99)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46198) (comment: 01277_alter_rename_column_constraint_zookeeper_long.sql) (query 3, line 19) (in query: INSERT INTO table_for_rename1 SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number + 1), toString(number + 2) from numbers(9);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:50:21.998620 [ 5110 ] {f0f8997d-589e-4a0d-95e5-b634ea3ef8e4} executeQuery: Code: 36. DB::Exception: Lambda age_max -> (SELECT uid FROM users WHERE users.age < age_max ORDER BY users.age DESC LIMIT 1) expect 1 arguments. Actual 3. In scope age_max -> (SELECT uid FROM users WHERE users.age < age_max ORDER BY users.age DESC LIMIT 1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 977, line 979) (in query: SELECT oldest_before([], [], []);) 2025.06.13 15:50:22.013113 [ 4107 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_zmookgdx.table_for_rename1 (1f35adba-c40f-4270-8870-35eb4ecb9a99)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:50:22.032323 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: Lambda age_max -> (SELECT uid FROM users WHERE users.age < age_max ORDER BY users.age DESC LIMIT 1) expect 1 arguments. Actual 3. In scope age_max -> (SELECT uid FROM users WHERE users.age < age_max ORDER BY users.age DESC LIMIT 1). (BAD_ARGUMENTS) 2025.06.13 15:50:22.147991 [ 5110 ] {86b353a6-3cc3-4996-8456-1713f977cf50} executeQuery: Code: 43. DB::Exception: Illegal type (Array(Nothing)) of 1 argument of function or: In scope SELECT [] OR [] OR []. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 978, line 980) (in query: SELECT or([], [], []);) 2025.06.13 15:50:22.181643 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(Nothing)) of 1 argument of function or: In scope SELECT [] OR [] OR []. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:22.294229 [ 3498 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6888017a-9e39-42fd-8e96-641721e202df::202506_70_125_11}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab57af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab1fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003122f56b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d8e4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:22.304479 [ 6234 ] {1bedf8c4-8e4c-4a3e-9f24-de98b2ad4ea3} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_zmookgdx.table_for_rename1 (1f35adba-c40f-4270-8870-35eb4ecb9a99)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36536) (comment: 01277_alter_rename_column_constraint_zookeeper_long.sql) (in query: DROP DATABASE IF EXISTS test_zmookgdx SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:50:22.316168 [ 6234 ] {1bedf8c4-8e4c-4a3e-9f24-de98b2ad4ea3} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_zmookgdx.table_for_rename1 (1f35adba-c40f-4270-8870-35eb4ecb9a99)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:22.364919 [ 5110 ] {1d611faa-0508-407e-bc0c-c314a44bea1d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'overlay'. Expected: String, got: Array(Nothing): In scope SELECT overlay([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 979, line 981) (in query: SELECT overlay([], [], []);) 2025.06.13 15:50:22.401735 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'overlay'. Expected: String, got: Array(Nothing): In scope SELECT overlay([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:22.572853 [ 5110 ] {150330d3-b6a8-4f19-9c28-8f012f35fa9a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'overlayUTF8'. Expected: String, got: Array(Nothing): In scope SELECT overlayUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 980, line 982) (in query: SELECT overlayUTF8([], [], []);) 2025.06.13 15:50:22.600623 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'overlayUTF8'. Expected: String, got: Array(Nothing): In scope SELECT overlayUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:22.678058 [ 34301 ] {49c04bbf-379f-490e-a2b9-0052464ec8d8} executeQuery: Code: 57. DB::Exception: Table test_azve06b2.x already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46082) (comment: 01056_create_table_as_with_sorting_clauses.sql) (query 12, line 16) (in query: CREATE TABLE x (`CounterID` UInt32, `EventDate` Date, `UserID` UInt64) ENGINE = MergeTree PRIMARY KEY (CounterID, EventDate, intHash32(UserID));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:50:22.829077 [ 34301 ] {} TCPHandler: Code: 57. DB::Exception: Table test_azve06b2.x already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:50:22.846903 [ 5110 ] {6e56172b-6e55-4378-b494-e1b22508e3ef} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 981, line 983) (in query: SELECT parseDateTime([], [], []);) 2025.06.13 15:50:22.861793 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:22.976978 [ 5110 ] {11fa9c41-24fd-4773-ba84-44bb1d22372c} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffort doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffort([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 982, line 984) (in query: SELECT parseDateTime32BestEffort([], [], []);) 2025.06.13 15:50:23.001427 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffort doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffort([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:23.163785 [ 5110 ] {1fe93c5e-5e5d-4472-a02b-d8db88705230} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 983, line 985) (in query: SELECT parseDateTime32BestEffortOrNull([], [], []);) 2025.06.13 15:50:23.195281 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:23.366131 [ 5110 ] {125b83d2-d2a3-4dd6-a631-a37fb778b3cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 984, line 986) (in query: SELECT parseDateTime32BestEffortOrZero([], [], []);) 2025.06.13 15:50:23.417158 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:23.568522 [ 5110 ] {eb1695be-f0f7-4401-a250-102a77da0edd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 985, line 987) (in query: SELECT parseDateTime64([], [], []);) 2025.06.13 15:50:23.593872 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:23.808934 [ 5110 ] {62e0e581-7f8c-4d8b-a405-535e80d262c5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffort'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 986, line 988) (in query: SELECT parseDateTime64BestEffort([], [], []);) 2025.06.13 15:50:23.833288 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffort'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:24.024849 [ 5110 ] {ac0b9bab-6483-4678-b4a0-fda9a9ab0664} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 987, line 989) (in query: SELECT parseDateTime64BestEffortOrNull([], [], []);) 2025.06.13 15:50:24.058466 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:24.187758 [ 5110 ] {69719e3c-aa49-48b8-8eab-d84d6377aa41} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortOrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 988, line 990) (in query: SELECT parseDateTime64BestEffortOrZero([], [], []);) 2025.06.13 15:50:24.201898 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortOrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:24.332694 [ 5110 ] {34dc462b-a594-42d8-b024-c668824a47f9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUS'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUS([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 989, line 991) (in query: SELECT parseDateTime64BestEffortUS([], [], []);) 2025.06.13 15:50:24.342859 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUS'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUS([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:24.491930 [ 5110 ] {623b4e75-4c01-4b3c-90c7-c7498cbb00ac} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUSOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 990, line 992) (in query: SELECT parseDateTime64BestEffortUSOrNull([], [], []);) 2025.06.13 15:50:24.509130 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUSOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:24.515680 [ 7279 ] {c50ca29b-4c9d-4870-aa27-e268eb1c4456} 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.20286.altinityantalya (altinity build)) (from [::1]:38708) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:50:24.537879 [ 7279 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9ab05 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002cc9a0a5 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002cc99102 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5759: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbfb0e0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:50:24.676220 [ 5110 ] {b1e38de1-fe08-4af3-8cfd-0e33b7a2ce9d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUSOrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 991, line 993) (in query: SELECT parseDateTime64BestEffortUSOrZero([], [], []);) 2025.06.13 15:50:24.746776 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUSOrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:24.962226 [ 5110 ] {971b92df-d395-41b8-a272-47977f4df54e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntax'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64InJodaSyntax([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 992, line 994) (in query: SELECT parseDateTime64InJodaSyntax([], [], []);) 2025.06.13 15:50:24.968706 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntax'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64InJodaSyntax([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:24.990792 [ 3692 ] {6e7d6b90-8954-4ff7-b202-dbb61c708107} InterpreterCheckQuery: Check query for table test_9.tp_1 (56fbd41a-3691-467d-993b-999007b11b2b) 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.20286.altinityantalya (altinity build)) 2025.06.13 15:50:25.151359 [ 5110 ] {966cd9c4-6a8a-4300-9c3b-db4197730b39} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64InJodaSyntaxOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 993, line 995) (in query: SELECT parseDateTime64InJodaSyntaxOrNull([], [], []);) 2025.06.13 15:50:25.161968 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64InJodaSyntaxOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:25.292514 [ 5110 ] {b5eb0383-7434-4417-9a95-166141878307} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64InJodaSyntaxOrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 994, line 996) (in query: SELECT parseDateTime64InJodaSyntaxOrZero([], [], []);) 2025.06.13 15:50:25.349401 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64InJodaSyntaxOrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:25.487242 [ 5110 ] {d717abc0-ed65-4d56-80e9-abdb0b67389d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64OrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 995, line 997) (in query: SELECT parseDateTime64OrNull([], [], []);) 2025.06.13 15:50:25.519957 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64OrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:25.687540 [ 5110 ] {ac108c53-aa0c-45ba-bc83-7c4082b852c3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64OrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 996, line 998) (in query: SELECT parseDateTime64OrZero([], [], []);) 2025.06.13 15:50:25.700325 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime64OrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:25.827373 [ 5110 ] {cc84e424-dbed-42f6-b743-0b6ed31dbf68} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffort'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTimeBestEffort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 997, line 999) (in query: SELECT parseDateTimeBestEffort([], [], []);) 2025.06.13 15:50:25.854512 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffort'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTimeBestEffort([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:25.986629 [ 5110 ] {7ada166e-a2b3-44b1-af04-428197ff30bc} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffortOrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTimeBestEffortOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 998, line 1000) (in query: SELECT parseDateTimeBestEffortOrNull([], [], []);) 2025.06.13 15:50:26.014957 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffortOrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTimeBestEffortOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:26.170869 [ 5110 ] {cb8f127f-3e42-480a-87ee-6dba3d55fc53} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffortOrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTimeBestEffortOrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 999, line 1001) (in query: SELECT parseDateTimeBestEffortOrZero([], [], []);) 2025.06.13 15:50:26.185028 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffortOrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTimeBestEffortOrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:26.377903 [ 5110 ] {3b916ae7-e38b-4a39-8ed6-c21082c6a3b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUS doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUS([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1000, line 1002) (in query: SELECT parseDateTimeBestEffortUS([], [], []);) 2025.06.13 15:50:26.404408 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUS doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUS([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:26.586049 [ 5110 ] {e5e6523a-af87-4cb9-b8b1-48b1e74fa605} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1001, line 1003) (in query: SELECT parseDateTimeBestEffortUSOrNull([], [], []);) 2025.06.13 15:50:26.596318 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:26.642137 [ 5110 ] {9bc556f0-ea57-41a9-9d46-9d68274c746f} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1002, line 1004) (in query: SELECT parseDateTimeBestEffortUSOrZero([], [], []);) 2025.06.13 15:50:26.648246 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:26.787038 [ 5110 ] {df8fee12-12ba-484a-8311-a3522d558043} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntax'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntax([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1003, line 1005) (in query: SELECT parseDateTimeInJodaSyntax([], [], []);) 2025.06.13 15:50:26.800756 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntax'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntax([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:27.021277 [ 5110 ] {398d3595-c4c1-4f87-8078-650862b173e1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntaxOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1004, line 1006) (in query: SELECT parseDateTimeInJodaSyntaxOrNull([], [], []);) 2025.06.13 15:50:27.075010 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntaxOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:27.310490 [ 5110 ] {f8c398f2-2afc-4d6c-926b-f54e759aac67} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntaxOrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1005, line 1007) (in query: SELECT parseDateTimeInJodaSyntaxOrZero([], [], []);) 2025.06.13 15:50:27.319341 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntaxOrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:27.500857 [ 5110 ] {b2a78653-59d0-41a1-b139-ede0560c7b65} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1006, line 1008) (in query: SELECT parseDateTimeOrNull([], [], []);) 2025.06.13 15:50:27.521479 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeOrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:27.756159 [ 5110 ] {ad56bc81-7dd1-4483-8e5f-c1a91edb4134} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeOrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1007, line 1009) (in query: SELECT parseDateTimeOrZero([], [], []);) 2025.06.13 15:50:27.791667 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeOrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:27.817212 [ 6234 ] {44255af5-6f13-46bd-8302-8f0ee6ea31fa} 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.20286.altinityantalya (altinity build)) (from [::1]:38692) (comment: 02812_pointwise_array_operations.sql) (query 14, line 14) (in query: SELECT ([12,13] % [5,6]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001e64a18b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001e0b2611 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:50:27.849961 [ 6234 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Array(UInt8) and Array(UInt8) of arguments of function modulo: In scope SELECT [12, 13] % [5, 6]. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001e64a18b 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001e0b2611 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:50:27.981219 [ 5110 ] {1011bd9a-9d74-4ac4-bbf2-1ab10712e80a} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1008, line 1010) (in query: SELECT parseReadableSize([], [], []);) 2025.06.13 15:50:28.016280 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:28.178470 [ 6234 ] {1913ac85-9155-481c-8687-38a005de3ac6} 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.20286.altinityantalya (altinity build)) (from [::1]:38692) (comment: 02812_pointwise_array_operations.sql) (query 15, line 15) (in query: SELECT ([2,3,4]-[1,-2,10,29]);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de78b24 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001de73a9c 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de700e0 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de6dfa8 9. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de77cd6 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001de73a9c 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de700e0 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de6dfa8 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:50:28.184843 [ 5110 ] {040ead33-556e-4a57-8203-aa1290c20390} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1009, line 1011) (in query: SELECT parseReadableSizeOrNull([], [], []);) 2025.06.13 15:50:28.210380 [ 6234 ] {} TCPHandler: Code: 190. DB::Exception: Two arguments for function minus must have equal sizes: In scope SELECT [2, 3, 4] - [1, -2, 10, 29]. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de78b24 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001de73a9c 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de700e0 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de6dfa8 9. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de77cd6 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001de73a9c 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de700e0 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001de6dfa8 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 2025.06.13 15:50:28.223665 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:28.370151 [ 5110 ] {b8ea1bbb-b648-48bc-a489-f2acd4a61321} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1010, line 1012) (in query: SELECT parseReadableSizeOrZero([], [], []);) 2025.06.13 15:50:28.405169 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:28.571213 [ 5110 ] {1ed662ce-da00-4e82-b34e-340c20ec9bbb} executeQuery: Code: 34. DB::Exception: Number of arguments for function parseTimeDelta doesn't match: passed 3, should be 1.: In scope SELECT parseTimeDelta([], [], []). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1011, line 1013) (in query: SELECT parseTimeDelta([], [], []);) 2025.06.13 15:50:28.624864 [ 5110 ] {} TCPHandler: Code: 34. DB::Exception: Number of arguments for function parseTimeDelta doesn't match: passed 3, should be 1.: In scope SELECT parseTimeDelta([], [], []). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.06.13 15:50:29.193506 [ 6234 ] {e58067fe-6e73-4c1a-8cbc-104df418af27} 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.20286.altinityantalya (altinity build)) (from [::1]:38692) (comment: 02812_pointwise_array_operations.sql) (query 18, line 18) (in query: SELECT x, y, x+y FROM a;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd120a4 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0dcdc 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0a540 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:50:29.268827 [ 6234 ] {} TCPHandler: Code: 190. DB::Exception: Two arguments for function plus must have equal sizes: while executing 'FUNCTION plus(__table1.x :: 2, __table1.y : 0) -> plus(__table1.x, __table1.y) Array(UInt64) : 3'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd120a4 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001fd0dcdc 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fd0a540 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:50:29.318558 [ 5110 ] {184d9acb-a6c7-4cf7-a94d-ba1b1624819d} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1014, line 1016) (in query: SELECT path([], [], []);) 2025.06.13 15:50:29.348257 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:29.509250 [ 5110 ] {b6c29139-6af8-469e-803b-d07ff65adfc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1015, line 1017) (in query: SELECT pathFull([], [], []);) 2025.06.13 15:50:29.536935 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:29.744716 [ 5110 ] {97a059f3-d43f-41b5-b856-07bc65b3dbdd} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1016, line 1018) (in query: SELECT percentRank([], [], []);) 2025.06.13 15:50:29.764093 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:50:30.014644 [ 5110 ] {803ebf57-9ae1-4a20-9a78-e50a3a188f1c} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1017, line 1019) (in query: SELECT percent_rank([], [], []);) 2025.06.13 15:50:30.030496 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:50:30.276141 [ 5110 ] {393dca0b-58b4-48f1-abf9-d76d49509db6} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1018, line 1020) (in query: SELECT pi([], [], []);) 2025.06.13 15:50:30.286241 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:30.463053 [ 5110 ] {79ac7b84-b595-4d00-ad41-ab0d6e8f5c8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1019, line 1021) (in query: SELECT plus([], [], []);) 2025.06.13 15:50:30.500522 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:30.676832 [ 5110 ] {2f5bd01b-962f-4bbf-9d2d-f67a0ed8ada0} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1020, line 1022) (in query: SELECT pmod([], [], []);) 2025.06.13 15:50:30.690087 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:30.839052 [ 5110 ] {f43d01d6-c438-4d9a-b9cb-68ef2a4db7fc} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1021, line 1023) (in query: SELECT pointInEllipses([], [], []);) 2025.06.13 15:50:30.879918 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:31.122632 [ 5110 ] {8ccd23f4-2b44-4123-9337-8b69807e62fd} executeQuery: Code: 43. DB::Exception: Argument 1 for function pointInPolygon must contain a tuple: In scope SELECT pointInPolygon([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1022, line 1024) (in query: SELECT pointInPolygon([], [], []);) 2025.06.13 15:50:31.141265 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 for function pointInPolygon must contain a tuple: In scope SELECT pointInPolygon([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:31.316096 [ 42488 ] {896b698b-140d-4a9c-88c4-6b15700d5283} InterpreterCheckQuery: Check query for table test_9.tp_1 (c6b54704-052c-4c02-b468-7cb36e083560) 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.20286.altinityantalya (altinity build)) 2025.06.13 15:50:31.333321 [ 5110 ] {dfd879c4-980e-401b-bbdb-3f7840fa3398} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1023, line 1025) (in query: SELECT polygonAreaCartesian([], [], []);) 2025.06.13 15:50:31.345111 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:31.517171 [ 5110 ] {da62dbe1-a8ad-4ede-a460-b775087c8016} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1024, line 1026) (in query: SELECT polygonAreaSpherical([], [], []);) 2025.06.13 15:50:31.537976 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:31.720103 [ 5110 ] {dc9cfb4b-2661-48ec-8d7e-17e8079af7d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1025, line 1027) (in query: SELECT polygonConvexHullCartesian([], [], []);) 2025.06.13 15:50:31.772052 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:31.945110 [ 5110 ] {a70cb705-910a-41f2-a9e4-27048d5495bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1026, line 1028) (in query: SELECT polygonPerimeterCartesian([], [], []);) 2025.06.13 15:50:31.951097 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:32.064684 [ 5110 ] {6402f177-8d34-430e-8cdd-cac21b01394c} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1027, line 1029) (in query: SELECT polygonPerimeterSpherical([], [], []);) 2025.06.13 15:50:32.081092 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:32.226128 [ 5110 ] {1853cb58-c045-4128-8d4a-6efb481e0cf6} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1028, line 1030) (in query: SELECT polygonsDistanceCartesian([], [], []);) 2025.06.13 15:50:32.267098 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:32.427643 [ 5110 ] {8f5dc9d6-90f1-404a-be62-49dc82d3aa4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1029, line 1031) (in query: SELECT polygonsDistanceSpherical([], [], []);) 2025.06.13 15:50:32.496947 [ 3676 ] {ce1ecc3d-25e4-4947-ac72-7a9c008b5981} InterpreterCheckQuery: Check query for table test_9.tp_1 (c6b54704-052c-4c02-b468-7cb36e083560) 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.20286.altinityantalya (altinity build)) 2025.06.13 15:50:32.519757 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:32.681008 [ 5110 ] {810629ad-6fad-4745-a62a-e81e07a87e43} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1030, line 1032) (in query: SELECT polygonsEqualsCartesian([], [], []);) 2025.06.13 15:50:32.698692 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:32.897576 [ 5110 ] {3177131d-73c9-49cf-aa15-4e34865885c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1031, line 1033) (in query: SELECT polygonsIntersectionCartesian([], [], []);) 2025.06.13 15:50:32.932063 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:33.091425 [ 5110 ] {602226fe-6bfe-4ade-a231-84e83b7aac90} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1032, line 1034) (in query: SELECT polygonsIntersectionSpherical([], [], []);) 2025.06.13 15:50:33.149545 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:33.406653 [ 5110 ] {e4dbacc0-e880-4ea7-a69f-3f7060c65194} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1033, line 1035) (in query: SELECT polygonsSymDifferenceCartesian([], [], []);) 2025.06.13 15:50:33.420458 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:33.548285 [ 5110 ] {5ba593bb-a0fb-415c-b2c8-4ac6de2e3960} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1034, line 1036) (in query: SELECT polygonsSymDifferenceSpherical([], [], []);) 2025.06.13 15:50:33.559400 [ 42501 ] {} test_9.tp_1 (c6b54704-052c-4c02-b468-7cb36e083560): Cannot quickly remove directory /var/lib/clickhouse/store/c6b/c6b54704-052c-4c02-b468-7cb36e083560/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/c6b/c6b54704-052c-4c02-b468-7cb36e083560/delete_tmp_0_1_1_0/pp.proj/x.cmrk2: , errno: 2, strerror: No such file or directory. (CANNOT_UNLINK) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:33.572897 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:33.823655 [ 5110 ] {9f83133e-6420-4916-8538-d88799171bfc} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1035, line 1037) (in query: SELECT polygonsUnionCartesian([], [], []);) 2025.06.13 15:50:33.847476 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:34.012913 [ 5110 ] {41933b1b-120b-498a-b134-0e265567e404} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1036, line 1038) (in query: SELECT polygonsUnionSpherical([], [], []);) 2025.06.13 15:50:34.056158 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:34.418935 [ 5110 ] {9c7aed24-5490-463f-afd0-d26f03b13c21} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1037, line 1039) (in query: SELECT polygonsWithinCartesian([], [], []);) 2025.06.13 15:50:34.508946 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:34.673438 [ 5110 ] {b7988889-6f7c-47f2-b299-23ce36672499} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1038, line 1040) (in query: SELECT polygonsWithinSpherical([], [], []);) 2025.06.13 15:50:34.697521 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:34.875537 [ 5110 ] {90088ee4-c01d-4a00-8263-600e3aa465b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function port doesn't match: passed 3, should be 1 or 2: In scope SELECT port([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1039, line 1041) (in query: SELECT port([], [], []);) 2025.06.13 15:50:34.907597 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function port doesn't match: passed 3, should be 1 or 2: In scope SELECT port([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:35.004215 [ 2868 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5528 similar messages) 2025.06.13 15:50:35.041615 [ 5110 ] {686605bb-bc04-4bb0-8231-501f61d7fb06} executeQuery: Code: 42. DB::Exception: Number of arguments for function portRFC doesn't match: passed 3, should be 1 or 2: In scope SELECT portRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1040, line 1042) (in query: SELECT portRFC([], [], []);) 2025.06.13 15:50:35.072272 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function portRFC doesn't match: passed 3, should be 1 or 2: In scope SELECT portRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:35.228201 [ 5110 ] {c0972125-f01c-468d-877f-38ab473430ce} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function position: In scope SELECT position([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1041, line 1043) (in query: SELECT position([], [], []);) 2025.06.13 15:50:35.256330 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function position: In scope SELECT position([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:35.466175 [ 5110 ] {dd064437-d7df-4e40-b174-cd316134a27c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionCaseInsensitive: In scope SELECT positionCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1042, line 1044) (in query: SELECT positionCaseInsensitive([], [], []);) 2025.06.13 15:50:35.550167 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionCaseInsensitive: In scope SELECT positionCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:35.709011 [ 5110 ] {a9591e42-0188-4cc8-97bb-0858b0af9c24} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionCaseInsensitiveUTF8: In scope SELECT positionCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1043, line 1045) (in query: SELECT positionCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:50:35.761447 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionCaseInsensitiveUTF8: In scope SELECT positionCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:35.955014 [ 5110 ] {dd9d9653-a0b3-4701-9949-cec094e1682f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionUTF8: In scope SELECT positionUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1044, line 1046) (in query: SELECT positionUTF8([], [], []);) 2025.06.13 15:50:35.971556 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionUTF8: In scope SELECT positionUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:36.143698 [ 5110 ] {4156ff8f-4f7d-4292-8fc1-ef644e23d004} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1045, line 1047) (in query: SELECT positiveModulo([], [], []);) 2025.06.13 15:50:36.197856 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:36.245046 [ 18510 ] {4d4a4879-e719-4a6b-8d62-8af21cc93ee5} executeQuery: Code: 57. DB::Exception: Table test_3.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:32946) (comment: 02901_predicate_pushdown_cte_stateful.sql) (query 2, line 3) (in query: CREATE TABLE t ( `rDate` String, `cpu_total` Int64 ) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:50:36.269227 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:50:36.284191 [ 5110 ] {eb98f3d2-76ee-44c1-a6a4-49a5042a4187} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1046, line 1048) (in query: SELECT positive_modulo([], [], []);) 2025.06.13 15:50:36.299973 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:36.537657 [ 5110 ] {c2ea7eb4-65a1-47bd-bf31-322e9e1f866f} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1047, line 1049) (in query: SELECT pow([], [], []);) 2025.06.13 15:50:36.599859 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:36.728149 [ 5110 ] {3e0e6c83-0f15-46b1-a4db-a1e6ec47cdfe} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1048, line 1050) (in query: SELECT power([], [], []);) 2025.06.13 15:50:36.761188 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:36.928697 [ 5110 ] {18c29dc8-5c2f-4c4b-b0e2-c3ff641bd95e} executeQuery: Code: 43. DB::Exception: The first argument type of function printf is Array(Nothing), but String type is expected: In scope SELECT printf([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1049, line 1051) (in query: SELECT printf([], [], []);) 2025.06.13 15:50:36.965933 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: The first argument type of function printf is Array(Nothing), but String type is expected: In scope SELECT printf([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:37.076292 [ 5110 ] {316b731e-ef67-41bc-a3c1-65005aa6dd79} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1050, line 1052) (in query: SELECT proportionsZTest([], [], []);) 2025.06.13 15:50:37.081874 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:37.212487 [ 5110 ] {15511d71-a007-42c3-9609-1d8907a5430c} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1051, line 1053) (in query: SELECT protocol([], [], []);) 2025.06.13 15:50:37.238752 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:37.379531 [ 5110 ] {879cb4c7-8de4-4938-b062-35504bf6631f} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1052, line 1054) (in query: SELECT punycodeDecode([], [], []);) 2025.06.13 15:50:37.388155 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:37.491291 [ 5110 ] {fa7a8b1e-8153-4c94-acbf-e884df8c732b} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1053, line 1055) (in query: SELECT punycodeEncode([], [], []);) 2025.06.13 15:50:37.497416 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:37.574569 [ 5110 ] {938a08a9-a940-4a5b-9198-77a3ef943d30} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1054, line 1056) (in query: SELECT quantile([], [], []);) 2025.06.13 15:50:37.580178 [ 5978 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:37.619628 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:37.798533 [ 5110 ] {ae0057db-3941-4825-9425-1d284330e76f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1055, line 1057) (in query: SELECT quantileBFloat16([], [], []);) 2025.06.13 15:50:37.821014 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:37.913721 [ 5110 ] {b41733f0-ec0a-41ef-81b8-408785eb9feb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1056, line 1058) (in query: SELECT quantileBFloat16Weighted([], [], []);) 2025.06.13 15:50:37.944683 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:38.030303 [ 5110 ] {f46f4c1b-0448-4fc4-82c5-8c9b48eda8b8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1057, line 1059) (in query: SELECT quantileDD([], [], []);) 2025.06.13 15:50:38.039041 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:38.101518 [ 5110 ] {73980d92-98a7-46b0-a77c-6043e8eacec9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1058, line 1060) (in query: SELECT quantileDeterministic([], [], []);) 2025.06.13 15:50:38.141502 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:38.320128 [ 5110 ] {1b13dd1c-f460-45af-88a6-36745b5485e3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1059, line 1061) (in query: SELECT quantileExact([], [], []);) 2025.06.13 15:50:38.348038 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:38.473693 [ 5110 ] {1f253c0d-7f60-4291-93b9-5b2b70ecea65} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1060, line 1062) (in query: SELECT quantileExactExclusive([], [], []);) 2025.06.13 15:50:38.482073 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:38.552487 [ 5110 ] {e1de576b-5ab9-4d4c-af62-721416a84956} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1061, line 1063) (in query: SELECT quantileExactHigh([], [], []);) 2025.06.13 15:50:38.559274 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:38.688564 [ 5110 ] {4334ac4c-7167-42b7-a601-f70573855f99} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1062, line 1064) (in query: SELECT quantileExactInclusive([], [], []);) 2025.06.13 15:50:38.715995 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:38.922297 [ 5110 ] {da97f1ad-2be2-4e75-922f-04b5999e749d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1063, line 1065) (in query: SELECT quantileExactLow([], [], []);) 2025.06.13 15:50:38.933410 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:39.039766 [ 5110 ] {b7a2d0b2-f3df-4569-b047-1368ecc08020} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1064, line 1066) (in query: SELECT quantileExactWeighted([], [], []);) 2025.06.13 15:50:39.044361 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:39.122645 [ 5110 ] {d5ffa1bd-de73-43a1-b730-73fe59ff72c5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1065, line 1067) (in query: SELECT quantileExactWeightedInterpolated([], [], []);) 2025.06.13 15:50:39.132641 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:39.216527 [ 5110 ] {5b36682b-f953-4e39-8859-4dfa4b032be6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1066, line 1068) (in query: SELECT quantileGK([], [], []);) 2025.06.13 15:50:39.261712 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:39.392470 [ 5110 ] {31d0488e-386e-4713-abe1-48bd6562b4cb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1067, line 1069) (in query: SELECT quantileInterpolatedWeighted([], [], []);) 2025.06.13 15:50:39.402776 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:39.547785 [ 5110 ] {71697be7-337b-4b5e-acff-bf7863eb1698} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1068, line 1070) (in query: SELECT quantileTDigest([], [], []);) 2025.06.13 15:50:39.557113 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:39.657869 [ 5110 ] {76ba0020-595a-4bab-9df5-5a4b814c07f5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1069, line 1071) (in query: SELECT quantileTDigestWeighted([], [], []);) 2025.06.13 15:50:39.681488 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:39.815893 [ 5110 ] {ac99d5b7-bf16-4aee-9128-4b077b0c59d7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1070, line 1072) (in query: SELECT quantileTiming([], [], []);) 2025.06.13 15:50:39.833786 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:39.982760 [ 5110 ] {75f3a04b-a5b9-4319-b0f0-2783598b5cd3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1071, line 1073) (in query: SELECT quantileTimingWeighted([], [], []);) 2025.06.13 15:50:40.004306 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:40.164404 [ 5110 ] {992ae4c8-c909-4055-8e1c-c2a22a306675} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1072, line 1074) (in query: SELECT quantiles([], [], []);) 2025.06.13 15:50:40.190261 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:40.307162 [ 5110 ] {3e53fa73-6300-4bd0-a626-4ddeb70eb082} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1073, line 1075) (in query: SELECT quantilesBFloat16([], [], []);) 2025.06.13 15:50:40.313932 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:40.405985 [ 5110 ] {039aaa55-2021-4e55-a401-05da106bc66e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1074, line 1076) (in query: SELECT quantilesBFloat16Weighted([], [], []);) 2025.06.13 15:50:40.418484 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:40.650495 [ 5110 ] {10d5295c-1c5e-491c-91e2-c606d75ebaa0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1075, line 1077) (in query: SELECT quantilesDD([], [], []);) 2025.06.13 15:50:40.659243 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:40.734565 [ 5110 ] {f921720c-31c2-4388-8bfd-41018904ac36} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1076, line 1078) (in query: SELECT quantilesDeterministic([], [], []);) 2025.06.13 15:50:40.777377 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:41.014665 [ 5110 ] {ddbfb1bf-377c-4084-be8c-19eef39708c8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1077, line 1079) (in query: SELECT quantilesExact([], [], []);) 2025.06.13 15:50:41.038524 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:41.244416 [ 5110 ] {e850b6a7-40b3-48a8-8ad5-1b0048d07133} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1078, line 1080) (in query: SELECT quantilesExactExclusive([], [], []);) 2025.06.13 15:50:41.279842 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:41.444972 [ 5110 ] {a1989879-8776-42d8-bf1d-6103f54cc7a9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1079, line 1081) (in query: SELECT quantilesExactHigh([], [], []);) 2025.06.13 15:50:41.451361 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:41.605614 [ 5110 ] {d7e70a2d-5b65-489c-a6d1-4014a50e28f9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1080, line 1082) (in query: SELECT quantilesExactInclusive([], [], []);) 2025.06.13 15:50:41.625584 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:41.774153 [ 5110 ] {bb327a7c-0703-44a1-b72e-30fd62e470e3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1081, line 1083) (in query: SELECT quantilesExactLow([], [], []);) 2025.06.13 15:50:41.814801 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:42.036323 [ 5110 ] {cbad0371-43f6-460e-953d-4264ce626530} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1082, line 1084) (in query: SELECT quantilesExactWeighted([], [], []);) 2025.06.13 15:50:42.062553 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:42.211688 [ 5110 ] {4c8f4c8e-b90d-464e-93b4-c678a71e03df} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1083, line 1085) (in query: SELECT quantilesExactWeightedInterpolated([], [], []);) 2025.06.13 15:50:42.242109 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:42.338005 [ 5110 ] {a8f61e32-9dce-44f2-8996-bdfd724fcc9b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1084, line 1086) (in query: SELECT quantilesGK([], [], []);) 2025.06.13 15:50:42.352813 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:42.464423 [ 5110 ] {276d5ce1-f8f0-4784-841e-6f144284b1ec} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1085, line 1087) (in query: SELECT quantilesInterpolatedWeighted([], [], []);) 2025.06.13 15:50:42.472657 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:42.662266 [ 5110 ] {3a42c61e-2cf5-43cf-9c6c-8826b6e036e7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1086, line 1088) (in query: SELECT quantilesTDigest([], [], []);) 2025.06.13 15:50:42.674112 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:42.770113 [ 5110 ] {5c3a0815-3722-4a0f-8d29-4c9ee27f0265} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1087, line 1089) (in query: SELECT quantilesTDigestWeighted([], [], []);) 2025.06.13 15:50:42.784653 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:42.915720 [ 5110 ] {30cfb867-7c66-4695-95bf-e6cadbe22f16} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1088, line 1090) (in query: SELECT quantilesTiming([], [], []);) 2025.06.13 15:50:42.930749 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:43.000760 [ 5110 ] {6dc7964c-524e-4aad-abbc-1cc19855cf39} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1089, line 1091) (in query: SELECT quantilesTimingWeighted([], [], []);) 2025.06.13 15:50:43.006847 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:43.108262 [ 5110 ] {76c301bc-efd2-4ae0-b6c0-4d66adb04ec9} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1090, line 1092) (in query: SELECT queryID([], [], []);) 2025.06.13 15:50:43.126857 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:43.271632 [ 5110 ] {5df8bc50-5ac3-4038-9dae-9826148e60c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1091, line 1093) (in query: SELECT queryString([], [], []);) 2025.06.13 15:50:43.294035 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:43.596040 [ 5110 ] {9bd3b332-fccb-465a-955a-727187647caa} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1092, line 1094) (in query: SELECT queryStringAndFragment([], [], []);) 2025.06.13 15:50:43.602950 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:43.669694 [ 5110 ] {6c3face6-ae14-46db-b3ea-483414367834} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1093, line 1095) (in query: SELECT query_id([], [], []);) 2025.06.13 15:50:43.679622 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:43.720187 [ 5110 ] {5b872a1b-01bd-4d93-85e2-6bb8d3b6036a} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1094, line 1096) (in query: SELECT radians([], [], []);) 2025.06.13 15:50:43.726970 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:43.784052 [ 5110 ] {943a008f-a384-4925-8ef9-474c3cddde3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1095, line 1097) (in query: SELECT rand([], [], []);) 2025.06.13 15:50:43.792222 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:43.951195 [ 5110 ] {1fd426dd-d27f-44b0-8e13-c04606ffc75f} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1096, line 1098) (in query: SELECT rand32([], [], []);) 2025.06.13 15:50:43.962676 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:44.094328 [ 5110 ] {0322ee06-6b05-47bf-9bc1-18ddbdff079c} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1097, line 1099) (in query: SELECT rand64([], [], []);) 2025.06.13 15:50:44.119130 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:44.206571 [ 5110 ] {200a27ae-e044-42bf-a037-a808575581b5} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randBernoulli. Should be 1 or 2: In scope SELECT randBernoulli([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1098, line 1100) (in query: SELECT randBernoulli([], [], []);) 2025.06.13 15:50:44.236139 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randBernoulli. Should be 1 or 2: In scope SELECT randBernoulli([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:44.312014 [ 5110 ] {e89fab58-4990-42db-98c8-cdaaa9053e90} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randBinomial, expected Float64 or integer: In scope SELECT randBinomial([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1099, line 1101) (in query: SELECT randBinomial([], [], []);) 2025.06.13 15:50:44.327299 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randBinomial, expected Float64 or integer: In scope SELECT randBinomial([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:44.378579 [ 5110 ] {d8e72be7-878d-4403-bd27-9a9f935c6cee} executeQuery: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1100, line 1102) (in query: SELECT randCanonical([], [], []);) 2025.06.13 15:50:44.386841 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:44.429874 [ 5110 ] {8b15f606-fce4-4840-b044-228a31a81d0b} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randChiSquared. Should be 1 or 2: In scope SELECT randChiSquared([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1101, line 1103) (in query: SELECT randChiSquared([], [], []);) 2025.06.13 15:50:44.436549 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randChiSquared. Should be 1 or 2: In scope SELECT randChiSquared([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:44.474142 [ 5110 ] {56c8b352-462d-45df-a152-0bbfbc74c0ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1102, line 1104) (in query: SELECT randConstant([], [], []);) 2025.06.13 15:50:44.491862 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:44.628079 [ 5110 ] {50afd713-21ed-4edc-b2ec-06c9948473c1} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randExponential. Should be 1 or 2: In scope SELECT randExponential([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1103, line 1105) (in query: SELECT randExponential([], [], []);) 2025.06.13 15:50:44.640871 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randExponential. Should be 1 or 2: In scope SELECT randExponential([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:44.708625 [ 5110 ] {2f9b64c5-62de-4882-b58f-84cc6dc78e81} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randFisherF, expected Float64 or integer: In scope SELECT randFisherF([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1104, line 1106) (in query: SELECT randFisherF([], [], []);) 2025.06.13 15:50:44.724480 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randFisherF, expected Float64 or integer: In scope SELECT randFisherF([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:44.779175 [ 5110 ] {2b473f8d-481b-4866-bcfd-8e3c9bf2d4a1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randLogNormal, expected Float64 or integer: In scope SELECT randLogNormal([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1105, line 1107) (in query: SELECT randLogNormal([], [], []);) 2025.06.13 15:50:44.784778 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randLogNormal, expected Float64 or integer: In scope SELECT randLogNormal([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:44.827876 [ 5110 ] {b4484cc0-804a-4fa4-81c9-31fba4ef1228} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randNegativeBinomial, expected Float64 or integer: In scope SELECT randNegativeBinomial([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1106, line 1108) (in query: SELECT randNegativeBinomial([], [], []);) 2025.06.13 15:50:44.833213 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randNegativeBinomial, expected Float64 or integer: In scope SELECT randNegativeBinomial([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:44.887709 [ 5110 ] {92d167b9-4f05-412a-97f2-26a50a90ade1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randNormal, expected Float64 or integer: In scope SELECT randNormal([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1107, line 1109) (in query: SELECT randNormal([], [], []);) 2025.06.13 15:50:44.895271 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randNormal, expected Float64 or integer: In scope SELECT randNormal([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:44.990948 [ 5110 ] {fe6fb4cc-dfdc-49ba-8635-93819140777c} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randPoisson. Should be 1 or 2: In scope SELECT randPoisson([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1108, line 1110) (in query: SELECT randPoisson([], [], []);) 2025.06.13 15:50:45.071383 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randPoisson. Should be 1 or 2: In scope SELECT randPoisson([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:45.186923 [ 5110 ] {76fdf2d4-87fc-47fb-b783-7cfc2bdafa21} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randStudentT. Should be 1 or 2: In scope SELECT randStudentT([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1109, line 1111) (in query: SELECT randStudentT([], [], []);) 2025.06.13 15:50:45.215067 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randStudentT. Should be 1 or 2: In scope SELECT randStudentT([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:45.336732 [ 5110 ] {23183f73-ea69-4da4-bafd-78a23a6fa9d0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randUniform, expected Float64 or integer: In scope SELECT randUniform([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1110, line 1112) (in query: SELECT randUniform([], [], []);) 2025.06.13 15:50:45.344300 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randUniform, expected Float64 or integer: In scope SELECT randUniform([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:45.403228 [ 5110 ] {7e6c9eeb-a88e-4707-b2c6-58d0e5294eb2} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1111, line 1113) (in query: SELECT randomFixedString([], [], []);) 2025.06.13 15:50:45.410110 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:45.485621 [ 5110 ] {c833af09-a068-44b3-9dd9-b3fc82e64c57} executeQuery: Code: 42. DB::Exception: Function randomPrintableASCII requires at most two arguments: the size of resulting string and optional disambiguation tag: In scope SELECT randomPrintableASCII([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1112, line 1114) (in query: SELECT randomPrintableASCII([], [], []);) 2025.06.13 15:50:45.490616 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function randomPrintableASCII requires at most two arguments: the size of resulting string and optional disambiguation tag: In scope SELECT randomPrintableASCII([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:45.675701 [ 5110 ] {2eeeeb22-2896-4363-b07e-2aae150bba1b} executeQuery: Code: 42. DB::Exception: Function randomString requires at most two arguments: the size of resulting string and optional disambiguation tag: In scope SELECT randomString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1113, line 1115) (in query: SELECT randomString([], [], []);) 2025.06.13 15:50:45.687032 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function randomString requires at most two arguments: the size of resulting string and optional disambiguation tag: In scope SELECT randomString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:45.796860 [ 5110 ] {0ecf83ff-13ac-4f7f-9f38-137d0c63a50e} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1114, line 1116) (in query: SELECT randomStringUTF8([], [], []);) 2025.06.13 15:50:45.808469 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:45.858504 [ 5110 ] {30c6f226-29eb-417e-bd08-1b3f312ca192} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function range: In scope SELECT range([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1115, line 1117) (in query: SELECT range([], [], []);) 2025.06.13 15:50:45.865836 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function range: In scope SELECT range([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:45.998619 [ 5110 ] {29c9d646-3ee6-49a7-b89c-3289adf52777} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1116, line 1118) (in query: SELECT rank([], [], []);) 2025.06.13 15:50:46.018831 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:50:46.155953 [ 5110 ] {59ce5f3b-0a0a-432c-b8d1-26303e7eea52} executeQuery: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1117, line 1119) (in query: SELECT rankCorr([], [], []);) 2025.06.13 15:50:46.163539 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:46.311478 [ 5110 ] {de93d3c8-153f-48ca-9fca-570d16c08b15} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1118, line 1120) (in query: SELECT readWKTLineString([], [], []);) 2025.06.13 15:50:46.346134 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:46.457919 [ 5110 ] {7a8435dc-3fa4-4c32-b73e-15900018fc94} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1119, line 1121) (in query: SELECT readWKTMultiLineString([], [], []);) 2025.06.13 15:50:46.534842 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:46.787705 [ 5110 ] {bfa0ce75-c624-4cf2-bb5c-407f61ef7432} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1120, line 1122) (in query: SELECT readWKTMultiPolygon([], [], []);) 2025.06.13 15:50:46.814217 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:46.912400 [ 5110 ] {09d1e7ee-c077-46ea-bfb9-25c5d9e1f0f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1121, line 1123) (in query: SELECT readWKTPoint([], [], []);) 2025.06.13 15:50:46.946691 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:47.040439 [ 5110 ] {2e6f7a40-a51b-4a2e-9ef0-b702771fe1c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1122, line 1124) (in query: SELECT readWKTPolygon([], [], []);) 2025.06.13 15:50:47.046039 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:47.117084 [ 5110 ] {ff686511-8293-4305-ba09-5b0af4fec1b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1123, line 1125) (in query: SELECT readWKTRing([], [], []);) 2025.06.13 15:50:47.126828 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:47.167570 [ 5110 ] {86280550-6b5b-461b-816a-214d3d8c6347} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nothing): In scope SELECT regexpExtract([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1124, line 1126) (in query: SELECT regexpExtract([], [], []);) 2025.06.13 15:50:47.177834 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nothing): In scope SELECT regexpExtract([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:47.255041 [ 5110 ] {d647aca4-29bd-4b70-b409-441c38cf0663} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1125, line 1127) (in query: SELECT regexpQuoteMeta([], [], []);) 2025.06.13 15:50:47.273334 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:47.466973 [ 5110 ] {dbd9c408-61ee-400a-bb77-200aa51fda2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionHierarchy doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionHierarchy([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1126, line 1128) (in query: SELECT regionHierarchy([], [], []);) 2025.06.13 15:50:47.491828 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionHierarchy doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionHierarchy([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:47.563949 [ 5110 ] {7406a1d1-f716-4e05-aa86-fb669988fa8a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function regionIn (must be UInt32): In scope SELECT regionIn([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1127, line 1129) (in query: SELECT regionIn([], [], []);) 2025.06.13 15:50:47.578586 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function regionIn (must be UInt32): In scope SELECT regionIn([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:47.712428 [ 5110 ] {79519bf9-e459-4690-bed7-efb942f26c35} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToArea doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToArea([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1128, line 1130) (in query: SELECT regionToArea([], [], []);) 2025.06.13 15:50:47.741811 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToArea doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToArea([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:47.885321 [ 5110 ] {67c6d4f1-c988-46e6-ac94-d0fb01b30f36} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToCity doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToCity([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1129, line 1131) (in query: SELECT regionToCity([], [], []);) 2025.06.13 15:50:47.918259 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToCity doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToCity([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:48.092474 [ 5110 ] {72e28a5d-70f0-4d9a-8a6f-64f1359e4230} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToContinent doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToContinent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1130, line 1132) (in query: SELECT regionToContinent([], [], []);) 2025.06.13 15:50:48.112613 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToContinent doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToContinent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:48.265789 [ 5110 ] {2e933fe7-e938-4013-b681-a40371d01453} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToCountry doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToCountry([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1131, line 1133) (in query: SELECT regionToCountry([], [], []);) 2025.06.13 15:50:48.279339 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToCountry doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToCountry([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:48.414788 [ 5110 ] {a99ff9ef-f0d3-4edc-bc4c-9e3c89823596} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToDistrict doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToDistrict([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1132, line 1134) (in query: SELECT regionToDistrict([], [], []);) 2025.06.13 15:50:48.446715 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToDistrict doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToDistrict([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:48.583363 [ 5110 ] {ee2d0107-3650-425e-9f5c-37111f6dda0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToName doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1133, line 1135) (in query: SELECT regionToName([], [], []);) 2025.06.13 15:50:48.604534 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToName doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:48.736545 [ 5110 ] {68da6843-aafd-46ce-83a7-eceab1b39cb7} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToPopulation doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToPopulation([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1134, line 1136) (in query: SELECT regionToPopulation([], [], []);) 2025.06.13 15:50:48.758249 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToPopulation doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToPopulation([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:48.874609 [ 5110 ] {76f2023f-abce-4c53-ae15-c8d2bb1d637a} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToTopContinent doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToTopContinent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1135, line 1137) (in query: SELECT regionToTopContinent([], [], []);) 2025.06.13 15:50:48.883388 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToTopContinent doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToTopContinent([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:48.930029 [ 5110 ] {d1b7884e-bff7-4167-8afa-4438c1346990} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1136, line 1138) (in query: SELECT reinterpret([], [], []);) 2025.06.13 15:50:48.944427 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:49.038097 [ 5110 ] {9ad4014b-7941-4a84-bacc-f019fc4750f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1137, line 1139) (in query: SELECT reinterpretAsDate([], [], []);) 2025.06.13 15:50:49.044093 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:49.195225 [ 5110 ] {adacfe3d-0ed5-456c-9212-a5b00a86dd07} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1138, line 1140) (in query: SELECT reinterpretAsDateTime([], [], []);) 2025.06.13 15:50:49.212112 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:49.294003 [ 5110 ] {e6722044-ef15-4ce5-99a8-ce2a0ea6a0f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1139, line 1141) (in query: SELECT reinterpretAsFixedString([], [], []);) 2025.06.13 15:50:49.304611 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:49.392027 [ 5110 ] {1f866d7d-aa04-4aef-821e-0fe24721af90} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1140, line 1142) (in query: SELECT reinterpretAsFloat32([], [], []);) 2025.06.13 15:50:49.399466 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:49.468417 [ 5110 ] {22a52130-cd2a-4719-841e-7027697fd6d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1141, line 1143) (in query: SELECT reinterpretAsFloat64([], [], []);) 2025.06.13 15:50:49.478510 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:49.622311 [ 5110 ] {91242fd8-912b-4983-93ed-7961eaead94e} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1142, line 1144) (in query: SELECT reinterpretAsInt128([], [], []);) 2025.06.13 15:50:49.647626 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:49.826734 [ 5110 ] {d60e3b6c-3f3b-4801-b4c6-a9ffc6a679c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1143, line 1145) (in query: SELECT reinterpretAsInt16([], [], []);) 2025.06.13 15:50:49.853992 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:50.081463 [ 5110 ] {14a5ab5c-b46e-4c00-b649-eac8dd53f2ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1144, line 1146) (in query: SELECT reinterpretAsInt256([], [], []);) 2025.06.13 15:50:50.095274 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:50.148994 [ 5110 ] {b1d9bfb5-b75c-4811-84b0-a9c3d20bf2b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1145, line 1147) (in query: SELECT reinterpretAsInt32([], [], []);) 2025.06.13 15:50:50.252772 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:50.347217 [ 5110 ] {d0e3cf2a-4d46-4ebc-a756-d1fe6d808f72} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1146, line 1148) (in query: SELECT reinterpretAsInt64([], [], []);) 2025.06.13 15:50:50.379849 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:50.478779 [ 5110 ] {f396f356-f1f1-4221-a1dd-df2e523417dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1147, line 1149) (in query: SELECT reinterpretAsInt8([], [], []);) 2025.06.13 15:50:50.506774 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:50.720590 [ 5110 ] {08acba48-da53-4be1-9cbc-2ebe9955f77b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1148, line 1150) (in query: SELECT reinterpretAsString([], [], []);) 2025.06.13 15:50:50.738166 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:50.889315 [ 5110 ] {5d998ed3-42d8-4a47-b4f9-f49fcc160587} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1149, line 1151) (in query: SELECT reinterpretAsUInt128([], [], []);) 2025.06.13 15:50:50.914199 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:51.090129 [ 5110 ] {fc2a7dfe-84b2-4ca8-a885-66e1fd6c9e32} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1150, line 1152) (in query: SELECT reinterpretAsUInt16([], [], []);) 2025.06.13 15:50:51.097820 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:51.222098 [ 5110 ] {994f50cf-2ddf-4655-8f3a-143da8841a0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1151, line 1153) (in query: SELECT reinterpretAsUInt256([], [], []);) 2025.06.13 15:50:51.248010 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:51.370695 [ 9642 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:51.515745 [ 5110 ] {a1935f47-43bc-402e-b32d-c6dff90cd5ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1152, line 1154) (in query: SELECT reinterpretAsUInt32([], [], []);) 2025.06.13 15:50:51.523884 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:51.595177 [ 5110 ] {b98ce4dc-5c57-4566-9e9f-89ae29fb6bcf} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1153, line 1155) (in query: SELECT reinterpretAsUInt64([], [], []);) 2025.06.13 15:50:51.600772 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:51.643508 [ 5110 ] {8d4b6bcf-9d64-446f-a1f3-e4e2c4b0bdfc} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1154, line 1156) (in query: SELECT reinterpretAsUInt8([], [], []);) 2025.06.13 15:50:51.648892 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:51.697962 [ 5110 ] {9237033e-a58e-40dd-8a03-ca3f8422e29e} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1155, line 1157) (in query: SELECT reinterpretAsUUID([], [], []);) 2025.06.13 15:50:51.756031 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:51.841333 [ 5110 ] {434c1ac7-c70a-4910-a1f1-8b58401bcfc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1156, line 1158) (in query: SELECT repeat([], [], []);) 2025.06.13 15:50:51.848238 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:51.970306 [ 5110 ] {368abb3f-0ded-417a-be92-7a57e2bcc293} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceAll'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT replace([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1157, line 1159) (in query: SELECT replace([], [], []);) 2025.06.13 15:50:52.003938 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceAll'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT replace([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:52.163053 [ 5110 ] {740d4c72-b645-4d64-86e7-e5daccf6c3ca} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceAll'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT replaceAll([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1158, line 1160) (in query: SELECT replaceAll([], [], []);) 2025.06.13 15:50:52.178711 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceAll'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT replaceAll([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:52.358401 [ 5110 ] {80a8a1db-bf9d-44e0-843d-f215a759565b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceOne'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT replaceOne([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1159, line 1161) (in query: SELECT replaceOne([], [], []);) 2025.06.13 15:50:52.381212 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceOne'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT replaceOne([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:52.554098 [ 5110 ] {5ff09a72-2827-4679-9afc-663ba6a8fa28} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpAll'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT replaceRegexpAll([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1160, line 1162) (in query: SELECT replaceRegexpAll([], [], []);) 2025.06.13 15:50:52.574732 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpAll'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT replaceRegexpAll([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:52.720710 [ 5110 ] {81991b48-9728-476a-9501-844ae9dfc63e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpOne'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT replaceRegexpOne([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1161, line 1163) (in query: SELECT replaceRegexpOne([], [], []);) 2025.06.13 15:50:52.728581 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpOne'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT replaceRegexpOne([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:52.791035 [ 2860 ] {4adfdc2f-51fa-426e-a6a6-eafe52ea4906} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:58816). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58816) (comment: 00653_verification_monotonic_data_load.sh) (query 1, line 1) (in query: SELECT count() FROM string_test_table WHERE toUInt64(val) == 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000316b9cb8 7. ./build_docker/./src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9539 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:50:52.818803 [ 2860 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:58816). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000316b9cb8 7. ./build_docker/./src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9539 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:50:53.107125 [ 5110 ] {70b9fbaa-f575-4709-813e-85473fdcfa5d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 0 of aggregate function retention, must be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1163, line 1165) (in query: SELECT retention([], [], []);) 2025.06.13 15:50:53.205406 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 0 of aggregate function retention, must be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:53.335723 [ 5110 ] {8e78d202-4c32-4827-b935-58e57757154c} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1164, line 1166) (in query: SELECT reverse([], [], []);) 2025.06.13 15:50:53.381083 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:53.506153 [ 9642 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40752, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:53.506966 [ 9642 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40752, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:53.539354 [ 3982 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40772, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:53.544157 [ 5110 ] {9125fbdb-5f28-4e6a-a470-bd34c25c2eb6} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1165, line 1167) (in query: SELECT reverseUTF8([], [], []);) 2025.06.13 15:50:53.548120 [ 3982 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40772, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:53.583871 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:53.787691 [ 5110 ] {5cffb21d-fff5-4067-87cb-1e00758e6d3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1166, line 1168) (in query: SELECT revision([], [], []);) 2025.06.13 15:50:53.845163 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:53.982631 [ 5110 ] {5a0b7aef-4db7-4aa9-a300-c3fd9211e636} executeQuery: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1167, line 1169) (in query: SELECT right([], [], []);) 2025.06.13 15:50:53.990026 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:54.150024 [ 5110 ] {1e41757a-47e7-428c-b75c-c882c17cea16} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function rightPad, should be string: In scope SELECT rightPad([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1168, line 1170) (in query: SELECT rightPad([], [], []);) 2025.06.13 15:50:54.177884 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function rightPad, should be string: In scope SELECT rightPad([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:54.325514 [ 5110 ] {2d9af804-5da4-493f-933e-a208e8b47c1e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function rightPadUTF8, should be string: In scope SELECT rightPadUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1169, line 1171) (in query: SELECT rightPadUTF8([], [], []);) 2025.06.13 15:50:54.352770 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function rightPadUTF8, should be string: In scope SELECT rightPadUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:54.457748 [ 34312 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40866, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:54.464603 [ 34312 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40866, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:54.547940 [ 5110 ] {65503cff-1d86-4e0a-a0f3-b9a08a6f3cf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1170, line 1172) (in query: SELECT rightUTF8([], [], []);) 2025.06.13 15:50:54.558828 [ 3982 ] {82b7725d-4f57-42d2-b50f-659939928682} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40848). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40848) (comment: 00653_verification_monotonic_data_load.sh) (query 1, line 1) (in query: SELECT count() FROM unsigned_integer_test_table WHERE toUInt64(val) == 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000316b9cb8 7. ./build_docker/./src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9539 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:50:54.561378 [ 4166 ] {598ac0ac-9aaa-4b6b-b831-ad9d7813739f} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40846). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40846) (comment: 00653_verification_monotonic_data_load.sh) (query 1, line 1) (in query: SELECT count() FROM unsigned_integer_test_table WHERE toInt16(val) == 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000316b9cb8 7. ./build_docker/./src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9539 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:50:54.569983 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:54.570218 [ 3982 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40848). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000316b9cb8 7. ./build_docker/./src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9539 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:50:54.610791 [ 4166 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40846). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000316b9cb8 7. ./build_docker/./src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9539 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:50:54.665949 [ 5110 ] {afdbe46f-6eaa-4052-8557-a55abfd74b45} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'round'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT round([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1171, line 1173) (in query: SELECT round([], [], []);) 2025.06.13 15:50:54.674167 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'round'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT round([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:54.825679 [ 5110 ] {ec04b2e4-59af-4a9d-851c-c5081039bb36} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1172, line 1174) (in query: SELECT roundAge([], [], []);) 2025.06.13 15:50:54.851979 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:54.996693 [ 5110 ] {4b7426e2-0278-46a9-a073-427a67b18aad} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'roundBankers'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT roundBankers([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1173, line 1175) (in query: SELECT roundBankers([], [], []);) 2025.06.13 15:50:55.041302 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'roundBankers'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT roundBankers([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:55.180396 [ 4166 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40896, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:55.182005 [ 4166 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40896, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:55.200115 [ 4163 ] {1de369e3-e582-4b4e-8450-33edc4074160} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 0, should be 1: In scope SELECT generateSerialID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58730) (comment: 03129_serial_test_zookeeper.sql) (query 5, line 8) (in query: SELECT generateSerialID();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002aceb2a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:50:55.227437 [ 5110 ] {d2d4ffc4-82bb-4891-94e1-476564e35b71} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1174, line 1176) (in query: SELECT roundDown([], [], []);) 2025.06.13 15:50:55.270078 [ 4163 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 0, should be 1: In scope SELECT generateSerialID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002aceb2a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:50:55.270542 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:55.435827 [ 5110 ] {09765cf5-4990-4380-8e41-f87b4f924058} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1175, line 1177) (in query: SELECT roundDuration([], [], []);) 2025.06.13 15:50:55.465854 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:55.541417 [ 4163 ] {32917735-71ee-4519-82c9-cfcc3902004d} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 2, should be 1: In scope SELECT generateSerialID('x', 'y'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58730) (comment: 03129_serial_test_zookeeper.sql) (query 6, line 9) (in query: SELECT generateSerialID('x', 'y');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002aceb2a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:50:55.545198 [ 4163 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 2, should be 1: In scope SELECT generateSerialID('x', 'y'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002aceb2a0 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:50:55.661376 [ 5110 ] {ad63bec4-1932-4d49-8370-40ded52ef79c} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1176, line 1178) (in query: SELECT roundToExp2([], [], []);) 2025.06.13 15:50:55.672216 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:55.768610 [ 4163 ] {23c9309f-87c1-4393-9ef3-c45cb6e14ed8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: UInt8: In scope SELECT generateSerialID(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58730) (comment: 03129_serial_test_zookeeper.sql) (query 7, line 10) (in query: SELECT generateSerialID(1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionSerial::getReturnTypeImpl(std::vector> const&) const @ 0x000000001af97e4a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:50:55.793023 [ 4163 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: UInt8: In scope SELECT generateSerialID(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionSerial::getReturnTypeImpl(std::vector> const&) const @ 0x000000001af97e4a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:50:55.906064 [ 5110 ] {d405988b-c8fe-45d8-95cb-7cad3baf7b0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1177, line 1179) (in query: SELECT rowNumberInAllBlocks([], [], []);) 2025.06.13 15:50:55.913125 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:56.028421 [ 4163 ] {a4f50bb5-06fa-4264-9563-d62bdf7c55d0} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: String: In scope SELECT generateSerialID(materialize('x')). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58730) (comment: 03129_serial_test_zookeeper.sql) (query 8, line 11) (in query: SELECT generateSerialID(materialize('x'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionSerial::getReturnTypeImpl(std::vector> const&) const @ 0x000000001af97e4a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:50:56.030066 [ 5110 ] {a124162d-f62a-44e0-877a-70d7e2060010} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1178, line 1180) (in query: SELECT rowNumberInBlock([], [], []);) 2025.06.13 15:50:56.056212 [ 4166 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40956, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:56.070332 [ 9642 ] {757a102c-98d8-44d5-a91a-384e1cbc93f0} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40940). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40940) (comment: 00653_verification_monotonic_data_load.sh) (query 1, line 1) (in query: SELECT count() FROM date_test_table WHERE toUInt8(val) == 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000316b9cb8 7. ./build_docker/./src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9539 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:50:56.071058 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:56.074595 [ 4166 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40956, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:56.075517 [ 4163 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 1st argument 'series_identifier' to function 'generateSerialID'. Expected: const String, got: String: In scope SELECT generateSerialID(materialize('x')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002ad0c717 5. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002ad0911a 6. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002ad08986 7. DB::(anonymous namespace)::FunctionSerial::getReturnTypeImpl(std::vector> const&) const @ 0x000000001af97e4a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:50:56.086349 [ 2860 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40930, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:56.089682 [ 9642 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40940). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2589: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000316b9cb8 7. ./build_docker/./src/Server/TCPHandler.cpp:1292: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9539 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:50:56.089825 [ 2860 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40930, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000023caac38 5. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000023cab895 6. DB::ReadBuffer::next() @ 0x0000000017e74832 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000316a359c 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:50:56.239134 [ 5110 ] {f7253f87-9914-44c6-bc1c-9e8dcfe789af} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1179, line 1181) (in query: SELECT row_number([], [], []);) 2025.06.13 15:50:56.248705 [ 5112 ] {00280b14-6c29-48e3-a3df-f259742906c5} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40992) (comment: 01825_type_json_1.sql) (query 1, line 3) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:50:56.251645 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:50:56.270068 [ 5112 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:50:56.436171 [ 5110 ] {5369dd4a-2f46-41a6-b44d-90bce1ead5a8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function rightPad, should be string: In scope SELECT rpad([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1180, line 1182) (in query: SELECT rpad([], [], []);) 2025.06.13 15:50:56.458847 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function rightPad, should be string: In scope SELECT rpad([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:56.569691 [ 4163 ] {36e9627c-f26d-4125-8639-3318502369d9} executeQuery: Code: 36. DB::Exception: Series name 'abcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghij' is too long. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58730) (comment: 03129_serial_test_zookeeper.sql) (query 9, line 12) (in query: SELECT generateSerialID('abcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghij');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. DB::(anonymous namespace)::FunctionSerial::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001af97840 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:50:56.574583 [ 5110 ] {7654543f-578b-444e-949e-7bf9b45bd0e9} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1181, line 1184) (in query: SELECT runningAccumulate([], [], []);) 2025.06.13 15:50:56.577587 [ 4163 ] {} TCPHandler: Code: 36. DB::Exception: Series name 'abcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghijabcdefghij' is too long. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. DB::(anonymous namespace)::FunctionSerial::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001af97840 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:50:56.583375 [ 5110 ] {} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:50:56.681815 [ 5110 ] {0a4ba68c-a3eb-4411-8ed0-20c0521852f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1182, line 1185) (in query: SELECT runningConcurrency([], [], []);) 2025.06.13 15:50:56.709314 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:56.857022 [ 5110 ] {3949be6c-89de-4567-b3a4-1cf810f4fa0d} 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.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1183, line 1186) (in query: SELECT runningDifference([], [], []);) 2025.06.13 15:50:56.878175 [ 5110 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:50:57.055127 [ 5110 ] {e97d752f-1681-471b-b5c0-54adaa070f90} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1184, line 1187) (in query: SELECT runningDifferenceStartingWithFirstValue([], [], []);) 2025.06.13 15:50:57.067959 [ 5110 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:50:57.205417 [ 5110 ] {ac20796d-b3e0-42a7-a3c5-7aec2f92b646} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1185, line 1188) (in query: SELECT s2CapContains([], [], []);) 2025.06.13 15:50:57.217603 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:57.275075 [ 5110 ] {9f08c60b-9318-4623-9aa6-7a5574e66f08} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1186, line 1189) (in query: SELECT s2CapUnion([], [], []);) 2025.06.13 15:50:57.285373 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:57.344703 [ 5110 ] {ddf8672d-676e-43d7-8324-59d141de19f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1187, line 1190) (in query: SELECT s2CellsIntersect([], [], []);) 2025.06.13 15:50:57.351258 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:57.387326 [ 5110 ] {dcce0212-60b2-4d37-9c6a-36bebe1dd9dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1188, line 1191) (in query: SELECT s2GetNeighbors([], [], []);) 2025.06.13 15:50:57.394208 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:57.466801 [ 5110 ] {a93c2e7c-fe5f-4a4d-9690-e69e066d6218} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 0 of function s2RectAdd. Must be UInt64: In scope SELECT s2RectAdd([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1189, line 1192) (in query: SELECT s2RectAdd([], [], []);) 2025.06.13 15:50:57.492398 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 0 of function s2RectAdd. Must be UInt64: In scope SELECT s2RectAdd([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:57.640673 [ 5110 ] {b7406bcc-274b-4a54-9e37-b5f099924730} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 0 of function s2RectContains. Must be UInt64: In scope SELECT s2RectContains([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1190, line 1193) (in query: SELECT s2RectContains([], [], []);) 2025.06.13 15:50:57.664060 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 0 of function s2RectContains. Must be UInt64: In scope SELECT s2RectContains([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:50:57.760830 [ 5110 ] {4b550c65-8bdb-4355-92fe-f364002d461b} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1191, line 1194) (in query: SELECT s2RectIntersection([], [], []);) 2025.06.13 15:50:57.777290 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:57.828619 [ 5110 ] {1b7958b9-3d54-4060-ba94-b25f493b9f81} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1192, line 1195) (in query: SELECT s2RectUnion([], [], []);) 2025.06.13 15:50:57.837126 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:57.900000 [ 5110 ] {26cf99f6-cab1-4233-9f74-159184603f4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1193, line 1196) (in query: SELECT s2ToGeo([], [], []);) 2025.06.13 15:50:57.918069 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:58.008831 [ 5110 ] {79f71d7b-57e6-4e16-a193-5aba288818a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1194, line 1197) (in query: SELECT scalarProduct([], [], []);) 2025.06.13 15:50:58.024147 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:58.134503 [ 5110 ] {cdf0fc94-2d15-4292-8979-29405451370a} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1195, line 1198) (in query: SELECT sequenceCount([], [], []);) 2025.06.13 15:50:58.152068 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:58.222269 [ 5110 ] {69acd128-66d6-4cdb-a57d-b59af14cbd24} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1196, line 1199) (in query: SELECT sequenceMatch([], [], []);) 2025.06.13 15:50:58.236200 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:58.399525 [ 5110 ] {1657a1c0-4cf4-4803-bd71-4a0a02e4f7f0} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceMatchEvents requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1197, line 1200) (in query: SELECT sequenceMatchEvents([], [], []);) 2025.06.13 15:50:58.414567 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceMatchEvents requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:58.565841 [ 5110 ] {63bd423c-94e2-4acb-ae5c-e7dc6f5349bd} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1198, line 1201) (in query: SELECT sequenceNextNode([], [], []);) 2025.06.13 15:50:58.581947 [ 5110 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.06.13 15:50:58.706951 [ 5110 ] {21d594d6-37bd-458c-9838-6d3bd9ed077f} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1199, line 1202) (in query: SELECT seriesDecomposeSTL([], [], []);) 2025.06.13 15:50:58.716271 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:58.894883 [ 5110 ] {68dfed64-335e-432a-8ca0-55625ff7c3ad} executeQuery: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 3.: In scope SELECT seriesOutliersDetectTukey([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1200, line 1203) (in query: SELECT seriesOutliersDetectTukey([], [], []);) 2025.06.13 15:50:58.900481 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 3.: In scope SELECT seriesOutliersDetectTukey([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:58.985532 [ 5110 ] {c2d5d4a8-6d39-4243-a7ce-6aa2a87f1a06} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1201, line 1204) (in query: SELECT seriesPeriodDetectFFT([], [], []);) 2025.06.13 15:50:59.042722 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:59.235343 [ 5110 ] {b4d59dbc-dc83-4190-9695-0c701da75273} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1202, line 1205) (in query: SELECT serverTimeZone([], [], []);) 2025.06.13 15:50:59.326696 [ 4163 ] {2ed9e350-e548-41a9-a3f7-5f9017df126a} executeQuery: Code: 290. DB::Exception: Too many series created by generateSerialID function, maximum: 3. This is controlled by the `max_autoincrement_series` setting. (LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58730) (comment: 03129_serial_test_zookeeper.sql) (query 12, line 18) (in query: SELECT generateSerialID('a');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, unsigned long const&) @ 0x000000001af9840f 5. DB::(anonymous namespace)::FunctionSerial::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001af97183 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:50:59.351660 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:59.380961 [ 4163 ] {} TCPHandler: Code: 290. DB::Exception: Too many series created by generateSerialID function, maximum: 3. This is controlled by the `max_autoincrement_series` setting. (LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, unsigned long const&) @ 0x000000001af9840f 5. DB::(anonymous namespace)::FunctionSerial::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001af97183 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000031dbc45f 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x00000000320ec47b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x000000002b3e49b6 16. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78f1e 17. ./build_docker/./src/Planner/Planner.cpp:1663: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd752e5 18. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:50:59.477551 [ 5110 ] {1e039b04-1a10-4f23-b628-f6ea5a269795} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1203, line 1206) (in query: SELECT serverTimezone([], [], []);) 2025.06.13 15:50:59.491075 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:59.579684 [ 18511 ] {74e64059-43ac-40ad-a1d6-43bb8186b3b6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:58746) (comment: 02911_backup_restore_keeper_map.sh) (query 1, line 1) (in query: DROP DATABASE test_jn1gj4rw_02911_keeper_map SYNC;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:50:59.614168 [ 18511 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:50:59.633490 [ 5110 ] {4c7f6070-4024-491c-b4b7-bd2493f64629} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1204, line 1207) (in query: SELECT serverUUID([], [], []);) 2025.06.13 15:50:59.682309 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:50:59.847310 [ 5110 ] {aa5a0e13-0b52-493a-9043-9ff8b46a7ac0} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1205, line 1208) (in query: SELECT shardCount([], [], []);) 2025.06.13 15:50:59.871327 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:00.036378 [ 5110 ] {cf643ef9-518e-4c10-8995-089c487717b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1206, line 1209) (in query: SELECT shardNum([], [], []);) 2025.06.13 15:51:00.064740 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:00.173740 [ 5110 ] {39fef39f-96d7-4978-b1ea-3db71fc587ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1207, line 1210) (in query: SELECT showCertificate([], [], []);) 2025.06.13 15:51:00.197497 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:00.286387 [ 8099 ] {078c4acf-9a59-4dc4-8d3d-1b5477be657b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55198) (comment: 00653_verification_monotonic_data_load.sh) (in query: DROP DATABASE IF EXISTS test_f15whego SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:51:00.291618 [ 8099 ] {078c4acf-9a59-4dc4-8d3d-1b5477be657b} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:51:00.348625 [ 5110 ] {34fb0dfc-84b1-4ab3-9b07-aa6dedfdd881} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1208, line 1211) (in query: SELECT sigmoid([], [], []);) 2025.06.13 15:51:00.389124 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:00.538070 [ 5110 ] {293c5276-d932-4544-b621-de8bc168fa69} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1209, line 1212) (in query: SELECT sign([], [], []);) 2025.06.13 15:51:00.578209 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:00.672487 [ 5110 ] {ff46bce4-d9e6-4d1f-93d8-f21a10c0ee7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1210, line 1213) (in query: SELECT simpleJSONExtractBool([], [], []);) 2025.06.13 15:51:00.686117 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:00.781875 [ 5110 ] {185209e7-f840-486e-813d-a7d239591717} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1211, line 1214) (in query: SELECT simpleJSONExtractFloat([], [], []);) 2025.06.13 15:51:00.790109 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:00.942000 [ 5110 ] {59c4cad9-8036-457d-8872-1bff46f0819f} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1212, line 1215) (in query: SELECT simpleJSONExtractInt([], [], []);) 2025.06.13 15:51:00.976898 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:01.117454 [ 5110 ] {14fc8fa4-c7af-4326-8842-2ba0c1dafe94} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1213, line 1216) (in query: SELECT simpleJSONExtractRaw([], [], []);) 2025.06.13 15:51:01.199618 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:01.327184 [ 5110 ] {a045b301-b255-4f5c-973c-c54bf1e62801} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1214, line 1217) (in query: SELECT simpleJSONExtractString([], [], []);) 2025.06.13 15:51:01.334850 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:01.472405 [ 5110 ] {2ceac960-06e8-4da0-80d6-f31319b75832} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1215, line 1218) (in query: SELECT simpleJSONExtractUInt([], [], []);) 2025.06.13 15:51:01.500578 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:01.618740 [ 5110 ] {a2e8081f-9995-4ee3-8f48-34623a1deb40} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1216, line 1219) (in query: SELECT simpleJSONHas([], [], []);) 2025.06.13 15:51:01.628783 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:01.772202 [ 5110 ] {4bd80087-d90d-4ff2-8849-5eaa2a1f8364} executeQuery: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1217, line 1220) (in query: SELECT simpleLinearRegression([], [], []);) 2025.06.13 15:51:01.807458 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:01.936890 [ 5110 ] {00a15cea-776a-41f3-b3ab-72870a56586b} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1218, line 1221) (in query: SELECT sin([], [], []);) 2025.06.13 15:51:01.968687 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:02.096931 [ 5110 ] {ce7fcdaf-e808-446f-8492-0d57c4ff545c} executeQuery: Code: 42. DB::Exception: Aggregate function singleValueOrNull requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1219, line 1222) (in query: SELECT singleValueOrNull([], [], []);) 2025.06.13 15:51:02.116770 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function singleValueOrNull requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:02.343498 [ 5110 ] {1452a99a-6505-4de4-8733-4da348517247} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1220, line 1223) (in query: SELECT sinh([], [], []);) 2025.06.13 15:51:02.352205 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:02.569626 [ 8430 ] {} TCPHandler: Code: 394. DB::Exception: Query '7958f631-cb13-4176-be51-62575d2a455b' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a4b0b 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 7. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:51:02.652203 [ 5110 ] {2376f90f-fc81-49cc-97a9-1ac06bf6d428} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed([], [], []). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1222, line 1225) (in query: SELECT sipHash128Keyed([], [], []);) 2025.06.13 15:51:02.666935 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed([], [], []). (BAD_ARGUMENTS) 2025.06.13 15:51:03.094485 [ 5110 ] {03bb70cd-a1c7-43b3-a4cc-53c4a9d0347b} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed([], [], []). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1224, line 1227) (in query: SELECT sipHash128ReferenceKeyed([], [], []);) 2025.06.13 15:51:03.111248 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed([], [], []). (BAD_ARGUMENTS) 2025.06.13 15:51:03.510459 [ 5110 ] {2d3f5912-457e-470f-9935-166a7cd21141} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed([], [], []). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1226, line 1229) (in query: SELECT sipHash64Keyed([], [], []);) 2025.06.13 15:51:03.525340 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed([], [], []). (BAD_ARGUMENTS) 2025.06.13 15:51:03.611054 [ 5110 ] {dbdc702b-73e2-4d0d-bdc2-43ec436c8c3c} executeQuery: Code: 42. DB::Exception: Aggregate function skewPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1227, line 1230) (in query: SELECT skewPop([], [], []);) 2025.06.13 15:51:03.708964 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function skewPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:03.788355 [ 5110 ] {6a7e89d5-1cd2-4cc8-a0be-931895779a20} executeQuery: Code: 42. DB::Exception: Aggregate function skewSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1228, line 1231) (in query: SELECT skewSamp([], [], []);) 2025.06.13 15:51:03.803948 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function skewSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:03.956283 [ 3895 ] {af7fe6a9-74ab-4783-b5f5-32729a3145cd} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51746) (comment: 03241_view_block_structure.sql) (in query: DROP DATABASE IF EXISTS test_b1xeemel SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:51:03.960800 [ 3895 ] {af7fe6a9-74ab-4783-b5f5-32729a3145cd} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:51:03.996132 [ 5110 ] {b69319e4-7539-483b-90fb-3ededb62205d} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1229, line 1232) (in query: SELECT sleep([], [], []);) 2025.06.13 15:51:04.002955 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:04.097729 [ 34301 ] {8ac1a30c-7bfb-409b-9585-c621d8a84820} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51748) (comment: 03241_view_block_structure.sql) (in query: DROP DATABASE IF EXISTS test_b1xeemel SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:51:04.103311 [ 5110 ] {ce0aad53-c78c-4f7e-af9f-95234d20a48e} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1230, line 1233) (in query: SELECT sleepEachRow([], [], []);) 2025.06.13 15:51:04.107996 [ 34301 ] {8ac1a30c-7bfb-409b-9585-c621d8a84820} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:51:04.124072 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:04.264120 [ 5110 ] {f33e5040-b310-4d49-b985-8c4da3c475d0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: Array(Nothing): In scope SELECT snowflakeIDToDateTime([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1231, line 1234) (in query: SELECT snowflakeIDToDateTime([], [], []);) 2025.06.13 15:51:04.274647 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: Array(Nothing): In scope SELECT snowflakeIDToDateTime([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:04.393703 [ 5110 ] {9632a585-e821-409e-a62a-d25ca8443df4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: Array(Nothing): In scope SELECT snowflakeIDToDateTime64([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1232, line 1235) (in query: SELECT snowflakeIDToDateTime64([], [], []);) 2025.06.13 15:51:04.399191 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: Array(Nothing): In scope SELECT snowflakeIDToDateTime64([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:04.450999 [ 5110 ] {704d1bdb-f669-4b32-be43-2582f88b2564} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT snowflakeToDateTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1233, line 1236) (in query: SELECT snowflakeToDateTime([], [], []);) 2025.06.13 15:51:04.461294 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT snowflakeToDateTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:04.629467 [ 5110 ] {d6179688-58ae-4a9f-a0ce-8c93018cc45a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime64'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT snowflakeToDateTime64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1234, line 1237) (in query: SELECT snowflakeToDateTime64([], [], []);) 2025.06.13 15:51:04.651969 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime64'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT snowflakeToDateTime64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:04.744129 [ 5110 ] {b08c0077-4d5c-46e4-bd62-c1e06815b5f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1235, line 1238) (in query: SELECT soundex([], [], []);) 2025.06.13 15:51:04.754294 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:04.883900 [ 5110 ] {277d6e6a-1935-4369-b20e-c80384460686} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1236, line 1239) (in query: SELECT space([], [], []);) 2025.06.13 15:51:04.889245 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:04.956399 [ 5110 ] {06902d69-37aa-4e61-8716-47612b0df610} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1237, line 1240) (in query: SELECT sparkBar([], [], []);) 2025.06.13 15:51:04.962845 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:05.099015 [ 5110 ] {d04f6926-c69f-4a77-a23d-ee81777fca6f} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1238, line 1241) (in query: SELECT sparkbar([], [], []);) 2025.06.13 15:51:05.120364 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:05.212848 [ 5110 ] {17710921-0858-4bd4-8d59-74ef6406f5f7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByAlpha([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1239, line 1242) (in query: SELECT splitByAlpha([], [], []);) 2025.06.13 15:51:05.229704 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByAlpha([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:05.321108 [ 5110 ] {d66ac6fc-8220-4d9f-9767-ee91e42c2bd7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByChar'. Expected: const String, got: Array(Nothing): In scope SELECT splitByChar([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1240, line 1243) (in query: SELECT splitByChar([], [], []);) 2025.06.13 15:51:05.326782 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByChar'. Expected: const String, got: Array(Nothing): In scope SELECT splitByChar([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:05.415445 [ 5110 ] {081a3544-ba98-4eac-aa3e-52a39826459a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByNonAlpha'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByNonAlpha([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1241, line 1244) (in query: SELECT splitByNonAlpha([], [], []);) 2025.06.13 15:51:05.420288 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByNonAlpha'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByNonAlpha([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:05.447280 [ 5110 ] {f28b1b3c-e074-437f-8765-567531f34aac} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByRegexp'. Expected: const String, got: Array(Nothing): In scope SELECT splitByRegexp([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1242, line 1245) (in query: SELECT splitByRegexp([], [], []);) 2025.06.13 15:51:05.452237 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByRegexp'. Expected: const String, got: Array(Nothing): In scope SELECT splitByRegexp([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:05.511900 [ 5110 ] {4f97224f-df7c-4cef-b1bc-d05810a1eff8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByString'. Expected: const String, got: Array(Nothing): In scope SELECT splitByString([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1243, line 1246) (in query: SELECT splitByString([], [], []);) 2025.06.13 15:51:05.519093 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByString'. Expected: const String, got: Array(Nothing): In scope SELECT splitByString([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:05.594298 [ 5110 ] {c191b08b-3cc4-4ee8-89b8-380a492d8526} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByWhitespace'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByWhitespace([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1244, line 1247) (in query: SELECT splitByWhitespace([], [], []);) 2025.06.13 15:51:05.601151 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByWhitespace'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByWhitespace([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:05.638323 [ 5110 ] {a47f4528-dbb4-4132-a217-1aa6f2516bc6} executeQuery: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nothing).: In scope SELECT sqid([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1245, line 1248) (in query: SELECT sqid([], [], []);) 2025.06.13 15:51:05.646998 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nothing).: In scope SELECT sqid([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:05.694111 [ 5110 ] {282c8755-c06d-4147-a387-641daca76734} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1246, line 1249) (in query: SELECT sqidDecode([], [], []);) 2025.06.13 15:51:05.702623 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:05.768329 [ 5110 ] {96f98609-aab1-4342-a2e3-faaf76be069d} executeQuery: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nothing).: In scope SELECT sqidEncode([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1247, line 1250) (in query: SELECT sqidEncode([], [], []);) 2025.06.13 15:51:05.787714 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nothing).: In scope SELECT sqidEncode([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:05.927524 [ 5110 ] {0bed6187-ebca-406a-980a-3b41e0e4b964} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1248, line 1251) (in query: SELECT sqrt([], [], []);) 2025.06.13 15:51:05.943945 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:06.117617 [ 5110 ] {be743f34-551e-4e00-831e-35bed77e737e} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1249, line 1252) (in query: SELECT startsWith([], [], []);) 2025.06.13 15:51:06.137046 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:06.261865 [ 5110 ] {05ca2d19-522b-4611-8d40-2331d12627eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1250, line 1253) (in query: SELECT startsWithUTF8([], [], []);) 2025.06.13 15:51:06.278921 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:06.457404 [ 5110 ] {eb882ae8-13ee-497d-b5a5-a44648ad7573} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1251, line 1254) (in query: SELECT stddevPop([], [], []);) 2025.06.13 15:51:06.468167 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:06.539510 [ 34347 ] {5b838d8e-ba0f-4cb9-b99f-fcbbd48c992a} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 3005.698442 ms, maximum: 3000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60302) (comment: 00976_max_execution_speed.sql) (query 2, line 2) (in query: SELECT count() FROM system.numbers;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:51:06.542885 [ 34347 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 3005.698442 ms, maximum: 3000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::checkTimeLimit() @ 0x0000000031819edd 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:218: DB::PipelineExecutor::finalizeExecution() @ 0x000000003181a159 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819c85 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:51:06.583466 [ 5110 ] {c32004bf-d6fe-48c9-a978-86e32df306ed} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1252, line 1255) (in query: SELECT stddevPopStable([], [], []);) 2025.06.13 15:51:06.608850 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:06.837828 [ 5110 ] {c1240d46-450e-44ca-bdbc-a1fa20fd55a7} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1253, line 1256) (in query: SELECT stddevSamp([], [], []);) 2025.06.13 15:51:06.843968 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:06.948160 [ 5110 ] {d0816ac1-15cd-4763-9b3b-2970c9ca6d4f} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1254, line 1257) (in query: SELECT stddevSampStable([], [], []);) 2025.06.13 15:51:06.970862 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:07.090096 [ 5110 ] {12c9733c-2e14-4d55-bbf9-a496de5a0f24} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1255, line 1258) (in query: SELECT stem([], [], []);) 2025.06.13 15:51:07.134744 [ 5110 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:51:07.298325 [ 5110 ] {cb1f8ddc-4596-476c-80e0-dcb07c0d77d3} executeQuery: Code: 43. DB::Exception: Argument 0 of type Array(Nothing) must be numeric for aggregate function stochasticLinearRegression. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1256, line 1259) (in query: SELECT stochasticLinearRegression([], [], []);) 2025.06.13 15:51:07.316408 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of type Array(Nothing) must be numeric for aggregate function stochasticLinearRegression. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:07.485163 [ 5110 ] {0efb26ee-1732-400f-b19e-9ce8c0144004} executeQuery: Code: 43. DB::Exception: Argument 0 of type Array(Nothing) must be numeric for aggregate function stochasticLogisticRegression. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1257, line 1260) (in query: SELECT stochasticLogisticRegression([], [], []);) 2025.06.13 15:51:07.495142 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of type Array(Nothing) must be numeric for aggregate function stochasticLogisticRegression. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:07.634714 [ 5110 ] {95669572-13f5-4690-8de1-415dfee17255} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nothing): In scope SELECT str_to_date([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1258, line 1261) (in query: SELECT str_to_date([], [], []);) 2025.06.13 15:51:07.642140 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nothing): In scope SELECT str_to_date([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:07.760944 [ 5110 ] {e9fbad8b-06b5-484c-a5d7-60d90c595e87} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT str_to_map([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1259, line 1262) (in query: SELECT str_to_map([], [], []);) 2025.06.13 15:51:07.787495 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT str_to_map([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:07.892714 [ 5110 ] {e8166fcb-0384-4154-82ff-e3aba019c937} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1260, line 1263) (in query: SELECT stringJaccardIndex([], [], []);) 2025.06.13 15:51:07.901492 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:08.030875 [ 5110 ] {2fe479ff-dde2-4d5c-bfe6-7af870608ff9} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1261, line 1264) (in query: SELECT stringJaccardIndexUTF8([], [], []);) 2025.06.13 15:51:08.066385 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:08.326833 [ 5110 ] {6163e065-7592-4af3-b318-3fcea22dd85e} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1262, line 1265) (in query: SELECT stringToH3([], [], []);) 2025.06.13 15:51:08.338069 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:08.450576 [ 5110 ] {38a7121b-ec14-4d25-9228-2dc4fd6e294e} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1263, line 1266) (in query: SELECT structureToCapnProtoSchema([], [], []);) 2025.06.13 15:51:08.465760 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:08.604480 [ 5110 ] {18c2fc89-9236-492a-8225-d00d4db2696a} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1264, line 1267) (in query: SELECT structureToProtobufSchema([], [], []);) 2025.06.13 15:51:08.625314 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:08.732967 [ 5110 ] {d9f653b3-0e43-44fa-8bc0-507d56e4dbaf} executeQuery: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1265, line 1268) (in query: SELECT studentTTest([], [], []);) 2025.06.13 15:51:08.748331 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:08.932725 [ 5110 ] {11dceb2a-a051-4416-a6a9-fce3a7b659b2} executeQuery: Code: 43. DB::Exception: First argument for function subBitmap must be a bitmap but it has type Array(Nothing).: In scope SELECT subBitmap([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1266, line 1269) (in query: SELECT subBitmap([], [], []);) 2025.06.13 15:51:08.955539 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function subBitmap must be a bitmap but it has type Array(Nothing).: In scope SELECT subBitmap([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:09.120001 [ 5110 ] {685f3e11-3250-4ba0-acc9-00841ce79993} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1267, line 1270) (in query: SELECT subDate([], [], []);) 2025.06.13 15:51:09.157793 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:09.260587 [ 5110 ] {a62c3629-7896-437e-9e9b-afe306ee1957} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substr([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1268, line 1271) (in query: SELECT substr([], [], []);) 2025.06.13 15:51:09.349480 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substr([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:09.436655 [ 5163 ] {30165909-6145-47f2-b8fd-0444966363ca} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239910e3 9. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017d46c46 10. ./src/Common/PODArray.h:228: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa595ce 11. ./build_docker/./src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa38684 12. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000002faa243d 13. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000002faa5006 14. ./build_docker/./src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x00000000317b6984 15. ./build_docker/./src/Server/TCPHandler.cpp:2483: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca320 16. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 17. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:51:09.535977 [ 5163 ] {30165909-6145-47f2-b8fd-0444966363ca} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60384) (comment: 01784_parallel_formatting_memory.sql) (query 2, line 2) (in query: SELECT range(65535) FROM system.one ARRAY JOIN range(65536) AS number;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239910e3 9. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017d46c46 10. ./src/Common/PODArray.h:228: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa595ce 11. ./build_docker/./src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa38684 12. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000002faa243d 13. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000002faa5006 14. ./build_docker/./src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x00000000317b6984 15. ./build_docker/./src/Server/TCPHandler.cpp:2483: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca320 16. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 17. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:51:09.564449 [ 5163 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x00000000239910e3 9. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::realloc<>(unsigned long) @ 0x0000000017d46c46 10. ./src/Common/PODArray.h:228: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa595ce 11. ./build_docker/./src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000002fa38684 12. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000002faa243d 13. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000002faa5006 14. ./build_docker/./src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x00000000317b6984 15. ./build_docker/./src/Server/TCPHandler.cpp:2483: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca320 16. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 17. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:51:09.637411 [ 5110 ] {b5fa207f-5696-4a6b-9e0a-f3fdd41a497a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substring([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1269, line 1272) (in query: SELECT substring([], [], []);) 2025.06.13 15:51:09.667907 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substring([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:09.806712 [ 5110 ] {ff71d5ec-c8a3-4cb1-90dc-a388f8b74c5c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substringIndex, String expected: In scope SELECT substringIndex([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1270, line 1273) (in query: SELECT substringIndex([], [], []);) 2025.06.13 15:51:09.817145 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substringIndex, String expected: In scope SELECT substringIndex([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:09.918580 [ 5110 ] {91746f56-d5e9-4b32-902c-f6b31d9b799a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substringIndexUTF8, String expected: In scope SELECT substringIndexUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1271, line 1274) (in query: SELECT substringIndexUTF8([], [], []);) 2025.06.13 15:51:09.927051 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substringIndexUTF8, String expected: In scope SELECT substringIndexUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:10.068971 [ 5110 ] {c97cffcb-4f4e-4988-bc37-07cced6941d2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substringUTF8, expected String: In scope SELECT substringUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1272, line 1275) (in query: SELECT substringUTF8([], [], []);) 2025.06.13 15:51:10.121547 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substringUTF8, expected String: In scope SELECT substringUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:10.621061 [ 5110 ] {a09afdd6-c987-4d46-be6a-8a21c6441c10} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractDays. Must be a DateTime/DateTime64: In scope SELECT subtractDays([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1273, line 1276) (in query: SELECT subtractDays([], [], []);) 2025.06.13 15:51:10.705005 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractDays. Must be a DateTime/DateTime64: In scope SELECT subtractDays([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:11.008564 [ 5110 ] {f4391b83-a533-4063-931b-821121763acf} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractHours. Must be a DateTime/DateTime64: In scope SELECT subtractHours([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1274, line 1277) (in query: SELECT subtractHours([], [], []);) 2025.06.13 15:51:11.023778 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractHours. Must be a DateTime/DateTime64: In scope SELECT subtractHours([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:11.280098 [ 5110 ] {e80d0951-6f59-4b3f-97d7-1aa15a77f5a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1275, line 1278) (in query: SELECT subtractInterval([], [], []);) 2025.06.13 15:51:11.341557 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:11.633658 [ 5110 ] {c5807179-f86d-4414-98b9-dd95b951be9e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMicroseconds. Must be a DateTime/DateTime64: In scope SELECT subtractMicroseconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1276, line 1279) (in query: SELECT subtractMicroseconds([], [], []);) 2025.06.13 15:51:11.640944 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMicroseconds. Must be a DateTime/DateTime64: In scope SELECT subtractMicroseconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:11.868571 [ 5110 ] {fcd8e399-ad30-49c4-8184-c2b9d9facae9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMilliseconds. Must be a DateTime/DateTime64: In scope SELECT subtractMilliseconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1277, line 1280) (in query: SELECT subtractMilliseconds([], [], []);) 2025.06.13 15:51:11.936364 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMilliseconds. Must be a DateTime/DateTime64: In scope SELECT subtractMilliseconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:12.296758 [ 5110 ] {84a80902-c341-4116-ab62-07dc516f9c7e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMinutes. Must be a DateTime/DateTime64: In scope SELECT subtractMinutes([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1278, line 1281) (in query: SELECT subtractMinutes([], [], []);) 2025.06.13 15:51:12.318904 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMinutes. Must be a DateTime/DateTime64: In scope SELECT subtractMinutes([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:12.504646 [ 5110 ] {c4baf3c9-7d05-4f2b-a43d-ba7bbce3f500} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMonths. Must be a DateTime/DateTime64: In scope SELECT subtractMonths([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1279, line 1282) (in query: SELECT subtractMonths([], [], []);) 2025.06.13 15:51:12.646570 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMonths. Must be a DateTime/DateTime64: In scope SELECT subtractMonths([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:13.052604 [ 5110 ] {5874954f-e68f-4241-9149-ef5db99471cb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractNanoseconds. Must be a DateTime/DateTime64: In scope SELECT subtractNanoseconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1280, line 1283) (in query: SELECT subtractNanoseconds([], [], []);) 2025.06.13 15:51:13.061951 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractNanoseconds. Must be a DateTime/DateTime64: In scope SELECT subtractNanoseconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:13.142869 [ 5110 ] {8594e8de-0d58-4d61-ae18-155adeafc756} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractQuarters. Must be a DateTime/DateTime64: In scope SELECT subtractQuarters([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1281, line 1284) (in query: SELECT subtractQuarters([], [], []);) 2025.06.13 15:51:13.146716 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractQuarters. Must be a DateTime/DateTime64: In scope SELECT subtractQuarters([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:13.332779 [ 5110 ] {687707bd-e19d-4521-921f-25fea64cf123} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractSeconds. Must be a DateTime/DateTime64: In scope SELECT subtractSeconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1282, line 1285) (in query: SELECT subtractSeconds([], [], []);) 2025.06.13 15:51:13.361127 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractSeconds. Must be a DateTime/DateTime64: In scope SELECT subtractSeconds([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:13.546427 [ 5110 ] {f69b072d-f08d-4263-9eb6-a5b3498213d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1283, line 1286) (in query: SELECT subtractTupleOfIntervals([], [], []);) 2025.06.13 15:51:13.577175 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:13.775271 [ 5110 ] {cff92a98-cbfd-4b4d-91e3-7439016ff191} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractWeeks. Must be a DateTime/DateTime64: In scope SELECT subtractWeeks([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1284, line 1287) (in query: SELECT subtractWeeks([], [], []);) 2025.06.13 15:51:13.826267 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractWeeks. Must be a DateTime/DateTime64: In scope SELECT subtractWeeks([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:14.002248 [ 5110 ] {a0e9269c-1787-4da2-b8b4-fa409a6e9ad0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractYears. Must be a DateTime/DateTime64: In scope SELECT subtractYears([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1285, line 1288) (in query: SELECT subtractYears([], [], []);) 2025.06.13 15:51:14.028429 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractYears. Must be a DateTime/DateTime64: In scope SELECT subtractYears([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:14.238590 [ 5110 ] {0409091e-371c-4573-99c4-0fa07021b859} executeQuery: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1286, line 1289) (in query: SELECT sum([], [], []);) 2025.06.13 15:51:14.252309 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:14.331747 [ 5110 ] {a918aaec-a0c5-4568-9042-5e84435b512e} executeQuery: Code: 42. DB::Exception: Aggregate function sumCount requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1287, line 1290) (in query: SELECT sumCount([], [], []);) 2025.06.13 15:51:14.364204 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sumCount requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:14.689974 [ 5110 ] {32d034a1-31d1-45fe-ad3c-d80c06aa8fba} executeQuery: Code: 42. DB::Exception: Aggregate function sumKahan requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1288, line 1291) (in query: SELECT sumKahan([], [], []);) 2025.06.13 15:51:14.705030 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sumKahan requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:14.905636 [ 5110 ] {6955bfe5-a59f-4237-ae8f-c76d4ae3bba3} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1289, line 1292) (in query: SELECT sumMapFiltered([], [], []);) 2025.06.13 15:51:14.999946 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:15.100142 [ 5110 ] {a32a75f3-0d77-4056-8c0f-8d971ef68fa9} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1290, line 1293) (in query: SELECT sumMapFilteredWithOverflow([], [], []);) 2025.06.13 15:51:15.118225 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:15.459615 [ 5110 ] {613d8881-0e5c-432f-989d-7d2d4e4f4599} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1291, line 1294) (in query: SELECT sumMapWithOverflow([], [], []);) 2025.06.13 15:51:15.463079 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:15.510172 [ 5110 ] {d88f3983-4676-411f-8213-cb955ad2d000} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1292, line 1295) (in query: SELECT sumMappedArrays([], [], []);) 2025.06.13 15:51:15.557402 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:15.900129 [ 5110 ] {d9219f70-07cd-4a45-997a-1e3e75d88f45} executeQuery: Code: 42. DB::Exception: Aggregate function sumWithOverflow requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1293, line 1296) (in query: SELECT sumWithOverflow([], [], []);) 2025.06.13 15:51:15.988555 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sumWithOverflow requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:16.198936 [ 5110 ] {5df7921f-4e50-475d-bdb3-fd608dbf786b} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT svg([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1294, line 1297) (in query: SELECT svg([], [], []);) 2025.06.13 15:51:16.216915 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT svg([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:16.499432 [ 5110 ] {d4baf338-04d6-439b-8f84-b4858dbd722b} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1295, line 1298) (in query: SELECT synonyms([], [], []);) 2025.06.13 15:51:16.516958 [ 5110 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:51:16.609605 [ 5110 ] {ca2c33ec-2aa9-48ed-a090-092087276594} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1296, line 1299) (in query: SELECT tan([], [], []);) 2025.06.13 15:51:16.629341 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:16.796925 [ 5110 ] {ff12b646-5417-4b72-8f94-948d056d6a3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1297, line 1300) (in query: SELECT tanh([], [], []);) 2025.06.13 15:51:16.802418 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:16.953526 [ 5110 ] {59c7d597-afb1-453c-b16b-50882172ea38} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1298, line 1301) (in query: SELECT tcpPort([], [], []);) 2025.06.13 15:51:17.035563 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:17.416971 [ 5110 ] {1f36ef0b-db76-409b-a931-483d7c482763} executeQuery: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1299, line 1302) (in query: SELECT test_function([], [], []);) 2025.06.13 15:51:17.457469 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:17.561414 [ 5110 ] {0378778b-cd63-46da-bf87-92a902371328} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1300, line 1303) (in query: SELECT tgamma([], [], []);) 2025.06.13 15:51:17.585140 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:17.910858 [ 5110 ] {d4e83c36-0afa-484c-82f9-4278a32d050f} executeQuery: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1301, line 1304) (in query: SELECT theilsU([], [], []);) 2025.06.13 15:51:17.916126 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:18.241446 [ 5110 ] {3b89d550-fa28-47bd-af6b-d18950f13d0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 3, should be 1 or 2: In scope SELECT throwIf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1302, line 1305) (in query: SELECT throwIf([], [], []);) 2025.06.13 15:51:18.246732 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 3, should be 1 or 2: In scope SELECT throwIf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:18.430111 [ 5110 ] {67e6adcb-ba71-4e94-8748-a09b8dda30a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1303, line 1306) (in query: SELECT tid([], [], []);) 2025.06.13 15:51:18.499978 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:18.852692 [ 5110 ] {a750c326-8f8d-4e94-a3c9-c1409ee27960} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1304, line 1307) (in query: SELECT timeDiff([], [], []);) 2025.06.13 15:51:18.865192 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:19.002507 [ 5110 ] {516f462e-fce2-46ea-98f9-0675cae3cc28} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlot doesn't match: passed 3, should be 1 or 2: In scope SELECT timeSlot([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1305, line 1308) (in query: SELECT timeSlot([], [], []);) 2025.06.13 15:51:19.024587 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlot doesn't match: passed 3, should be 1 or 2: In scope SELECT timeSlot([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:19.335467 [ 5110 ] {270ea13b-1b01-4505-ae53-d162ae62068f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function timeSlots. Must be DateTime or DateTime64.: In scope SELECT timeSlots([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1306, line 1309) (in query: SELECT timeSlots([], [], []);) 2025.06.13 15:51:19.346110 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function timeSlots. Must be DateTime or DateTime64.: In scope SELECT timeSlots([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:19.468254 [ 5110 ] {55491e41-088d-4f05-bd69-96904828f4a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1307, line 1310) (in query: SELECT timeZone([], [], []);) 2025.06.13 15:51:19.508856 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:19.655351 [ 5110 ] {93d81d89-44b0-4d25-9892-6e1ffec8acf7} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1308, line 1311) (in query: SELECT timeZoneOf([], [], []);) 2025.06.13 15:51:19.662843 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:19.820356 [ 5110 ] {fa72094b-1673-483b-bfb3-fb461baa7de0} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 3, should be 1 or 2: In scope SELECT timeZoneOffset([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1309, line 1312) (in query: SELECT timeZoneOffset([], [], []);) 2025.06.13 15:51:19.834343 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 3, should be 1 or 2: In scope SELECT timeZoneOffset([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:20.094826 [ 5110 ] {167cb59f-4454-4455-9d4e-8de262ecbde1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toStartOfInterval, expected a Date, Date32, DateTime or DateTime64: In scope SELECT time_bucket([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1310, line 1313) (in query: SELECT time_bucket([], [], []);) 2025.06.13 15:51:20.150853 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toStartOfInterval, expected a Date, Date32, DateTime or DateTime64: In scope SELECT time_bucket([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:20.400103 [ 5110 ] {14b6046b-ef58-4b05-bffe-10d364e95f34} 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([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1311, line 1314) (in query: SELECT timestamp([], [], []);) 2025.06.13 15:51:20.451457 [ 5110 ] {} 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([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:20.703479 [ 5110 ] {ad315861-5968-4b99-bb13-2b78defde594} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nothing): In scope SELECT dateDiff([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1312, line 1315) (in query: SELECT timestampDiff([], [], []);) 2025.06.13 15:51:20.746852 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nothing): In scope SELECT dateDiff([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:20.915574 [ 5110 ] {a87cb731-ba5c-4921-b439-727dfb163662} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nothing): In scope SELECT dateDiff([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1313, line 1316) (in query: SELECT timestamp_diff([], [], []);) 2025.06.13 15:51:21.032824 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nothing): In scope SELECT dateDiff([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:21.453045 [ 5110 ] {d072b3df-8961-4af2-906c-c6fdaba92f5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1314, line 1317) (in query: SELECT timezone([], [], []);) 2025.06.13 15:51:21.457092 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:21.529935 [ 5110 ] {c8efad04-7477-450c-b8c9-b4dde28e9756} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1315, line 1318) (in query: SELECT timezoneOf([], [], []);) 2025.06.13 15:51:21.533599 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:21.725471 [ 5110 ] {1f7a08cd-df8d-4aec-bb65-260f4987034b} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 3, should be 1 or 2: In scope SELECT timezoneOffset([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1316, line 1319) (in query: SELECT timezoneOffset([], [], []);) 2025.06.13 15:51:21.786097 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 3, should be 1 or 2: In scope SELECT timezoneOffset([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:22.009043 [ 5110 ] {bf3baa95-a3e8-42b3-a2c7-de1b46937fc0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toBFloat16'. Expected 1 argument, got 3 arguments: In scope SELECT toBFloat16([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1317, line 1320) (in query: SELECT toBFloat16([], [], []);) 2025.06.13 15:51:22.044163 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toBFloat16'. Expected 1 argument, got 3 arguments: In scope SELECT toBFloat16([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:22.196859 [ 5110 ] {45cf77b9-d2db-4118-8d0e-2e43dd3976c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBFloat16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toBFloat16OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1318, line 1321) (in query: SELECT toBFloat16OrNull([], [], []);) 2025.06.13 15:51:22.273871 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBFloat16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toBFloat16OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:22.518199 [ 5110 ] {fa4c5f71-31d4-45f7-a704-74a1f49de0d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBFloat16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toBFloat16OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1319, line 1322) (in query: SELECT toBFloat16OrZero([], [], []);) 2025.06.13 15:51:22.586426 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBFloat16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toBFloat16OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:22.816701 [ 5110 ] {22082d05-f5d2-4719-8341-0b7d81e7f531} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1320, line 1323) (in query: SELECT toBool([], [], []);) 2025.06.13 15:51:22.890599 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:23.093867 [ 5110 ] {7efac211-87d8-404a-bd99-9a988b161fe7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1321, line 1324) (in query: SELECT toColumnTypeName([], [], []);) 2025.06.13 15:51:23.113131 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:23.321991 [ 5110 ] {cb38c531-1ef7-4fe1-8c9d-d34400947ab0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1322, line 1325) (in query: SELECT toDate([], [], []);) 2025.06.13 15:51:23.408596 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:23.629235 [ 5110 ] {515a022d-93ef-4401-bb85-3dc11c3607a6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1323, line 1326) (in query: SELECT toDate32([], [], []);) 2025.06.13 15:51:23.646626 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:23.696716 [ 5110 ] {ecff79bc-baac-4979-950e-a4c0d6e2438c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1324, line 1327) (in query: SELECT toDate32OrDefault([], [], []);) 2025.06.13 15:51:23.742707 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:24.001923 [ 5110 ] {4670d0ac-cfae-4811-a742-e295e1088169} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDate32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1325, line 1328) (in query: SELECT toDate32OrNull([], [], []);) 2025.06.13 15:51:24.052891 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDate32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:24.248261 [ 5110 ] {3d27a17c-fcf5-4fcd-bfa6-799774d0ddd2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDate32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1326, line 1329) (in query: SELECT toDate32OrZero([], [], []);) 2025.06.13 15:51:24.286003 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDate32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:24.357764 [ 5110 ] {4c455e4c-06ab-4394-b038-fdd630b8eb53} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1327, line 1330) (in query: SELECT toDateOrDefault([], [], []);) 2025.06.13 15:51:24.371874 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:24.659492 [ 5110 ] {83a2e747-22c9-4ebf-934f-15d1a15817dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1328, line 1331) (in query: SELECT toDateOrNull([], [], []);) 2025.06.13 15:51:24.716022 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:24.998226 [ 5110 ] {ee0c53dd-72ca-4179-8a9d-f72649808978} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1329, line 1332) (in query: SELECT toDateOrZero([], [], []);) 2025.06.13 15:51:25.028011 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:25.343728 [ 5110 ] {96da4df1-2263-4f95-9ab4-4be85d507511} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDateTime([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1330, line 1333) (in query: SELECT toDateTime([], [], []);) 2025.06.13 15:51:25.387149 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDateTime([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:25.540830 [ 5110 ] {36fe5939-86b5-4f07-b319-8965dc66341e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime32'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateTime32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1331, line 1334) (in query: SELECT toDateTime32([], [], []);) 2025.06.13 15:51:25.556668 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime32'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateTime32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:25.751764 [ 5110 ] {d26e8411-915b-4a86-bd53-f0f111ede36d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDateTime64([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1332, line 1335) (in query: SELECT toDateTime64([], [], []);) 2025.06.13 15:51:25.812145 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDateTime64([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:26.053576 [ 5110 ] {bc9087bd-7815-41db-9147-f009e60b559a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDateTime64OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1333, line 1336) (in query: SELECT toDateTime64OrDefault([], [], []);) 2025.06.13 15:51:26.100630 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDateTime64OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:26.356578 [ 5110 ] {7c219e38-0a01-4455-825a-56a8b5fa54cc} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT toDateTime64OrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1334, line 1337) (in query: SELECT toDateTime64OrNull([], [], []);) 2025.06.13 15:51:26.458050 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT toDateTime64OrNull([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:26.739245 [ 5110 ] {6b7361f1-f4e9-44fa-815e-3775a64ce696} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT toDateTime64OrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1335, line 1338) (in query: SELECT toDateTime64OrZero([], [], []);) 2025.06.13 15:51:26.810477 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT toDateTime64OrZero([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:27.202922 [ 5110 ] {0325ae2e-26a8-4452-88fa-6e309f1de58f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Array(Nothing): In scope SELECT toDateTimeOrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1336, line 1339) (in query: SELECT toDateTimeOrDefault([], [], []);) 2025.06.13 15:51:27.228719 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Array(Nothing): In scope SELECT toDateTimeOrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:27.494995 [ 5110 ] {493ea88d-565b-4b8c-a9f6-69d6489c8219} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1337, line 1340) (in query: SELECT toDateTimeOrNull([], [], []);) 2025.06.13 15:51:27.531911 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:27.726460 [ 45816 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:51:27.910091 [ 5110 ] {954a6737-df89-4bc7-a1dd-78fb1e2e1dd3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1338, line 1341) (in query: SELECT toDateTimeOrZero([], [], []);) 2025.06.13 15:51:27.967644 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:28.110700 [ 5110 ] {eaccc108-21b7-419e-b8f7-8e061f6c5eb1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toDayOfMonth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1339, line 1342) (in query: SELECT toDayOfMonth([], [], []);) 2025.06.13 15:51:28.148392 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toDayOfMonth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:28.417422 [ 5110 ] {81213fb8-4e6f-49d8-849e-a36cc702cd49} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfWeek([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1340, line 1343) (in query: SELECT toDayOfWeek([], [], []);) 2025.06.13 15:51:28.446285 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfWeek([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:28.735083 [ 5110 ] {7c65a935-4ece-4571-a22c-1607c8c144bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toDayOfYear([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1341, line 1344) (in query: SELECT toDayOfYear([], [], []);) 2025.06.13 15:51:28.789959 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toDayOfYear([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:29.182291 [ 5110 ] {916a38a6-5d2c-4919-ad33-9db2604ed3c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 3, should be 1 or 2: In scope SELECT toDaysSinceYearZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1342, line 1345) (in query: SELECT toDaysSinceYearZero([], [], []);) 2025.06.13 15:51:29.235875 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 3, should be 1 or 2: In scope SELECT toDaysSinceYearZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:29.544752 [ 5110 ] {9185c81d-536b-42c0-a593-d43ffc06439a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal128([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1343, line 1346) (in query: SELECT toDecimal128([], [], []);) 2025.06.13 15:51:29.573367 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal128([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:29.703430 [ 5110 ] {2c3e7df4-c934-457f-b774-3de19b5adbef} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal128OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1344, line 1347) (in query: SELECT toDecimal128OrDefault([], [], []);) 2025.06.13 15:51:29.745911 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal128OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:29.976013 [ 5110 ] {e20c4409-33be-48da-b142-8756297099b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1345, line 1348) (in query: SELECT toDecimal128OrNull([], [], []);) 2025.06.13 15:51:29.991143 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:30.236999 [ 5110 ] {c33178d9-9eff-40e5-88dc-ee6b412faf18} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1346, line 1349) (in query: SELECT toDecimal128OrZero([], [], []);) 2025.06.13 15:51:30.248138 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:30.355255 [ 5110 ] {95719e47-cf50-45a9-9427-b4aa98703267} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1347, line 1350) (in query: SELECT toDecimal256([], [], []);) 2025.06.13 15:51:30.361177 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:30.459606 [ 5110 ] {835fe0be-fd40-4640-b95e-d492efe4aad0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal256OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1348, line 1351) (in query: SELECT toDecimal256OrDefault([], [], []);) 2025.06.13 15:51:30.465987 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal256OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:30.665404 [ 5110 ] {1678977b-1c56-4669-b848-4407851634cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1349, line 1352) (in query: SELECT toDecimal256OrNull([], [], []);) 2025.06.13 15:51:30.744195 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:30.979164 [ 5110 ] {48ab9f2c-1313-46ab-acd6-67895d13fe38} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1350, line 1353) (in query: SELECT toDecimal256OrZero([], [], []);) 2025.06.13 15:51:31.025816 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:31.092533 [ 5110 ] {4deced52-fb97-4dac-9940-fff71a184f3a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1351, line 1354) (in query: SELECT toDecimal32([], [], []);) 2025.06.13 15:51:31.125884 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:31.293781 [ 5110 ] {264a7137-d82e-4a36-bb5b-6380003cfdfd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal32OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1352, line 1355) (in query: SELECT toDecimal32OrDefault([], [], []);) 2025.06.13 15:51:31.297729 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal32OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:31.422883 [ 5110 ] {b53a9ae4-953e-40e9-8b31-3255f1b6b28a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1353, line 1356) (in query: SELECT toDecimal32OrNull([], [], []);) 2025.06.13 15:51:31.485829 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:31.603779 [ 5110 ] {0abc8a35-cf87-4521-a5bc-d49339ae2c98} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1354, line 1357) (in query: SELECT toDecimal32OrZero([], [], []);) 2025.06.13 15:51:31.624500 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:31.952550 [ 5110 ] {111d81ab-f3fa-44cb-81cc-76e0d1f204f5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1355, line 1358) (in query: SELECT toDecimal64([], [], []);) 2025.06.13 15:51:32.059869 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:32.543085 [ 5110 ] {d0bf8d55-eca7-4056-a1d3-8f3b30d6bc8b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal64OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1356, line 1359) (in query: SELECT toDecimal64OrDefault([], [], []);) 2025.06.13 15:51:32.576845 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal64OrDefault([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:32.765561 [ 5110 ] {26ad1155-38df-43c7-a9c1-ea5413346f86} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1357, line 1360) (in query: SELECT toDecimal64OrNull([], [], []);) 2025.06.13 15:51:32.800081 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:33.136590 [ 5110 ] {1092a33e-587a-4d0e-aa72-9e6b6d0bc479} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1358, line 1361) (in query: SELECT toDecimal64OrZero([], [], []);) 2025.06.13 15:51:33.141516 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:33.251287 [ 8101 ] {026bca6c-7d11-4556-ac59-724977256564} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60404) (comment: 00094_union_race_conditions_5.sh) (query 44, line 44) (in query: SELECT * FROM system.numbers_mt LIMIT 111;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:51:33.267870 [ 8101 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:51:33.354278 [ 5110 ] {154f32aa-d950-4c75-bbe4-17da706711a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1359, line 1362) (in query: SELECT toDecimalString([], [], []);) 2025.06.13 15:51:33.361244 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:33.598992 [ 5110 ] {517a3033-375c-422c-b4f3-db47757a3bbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1360, line 1363) (in query: SELECT toFixedString([], [], []);) 2025.06.13 15:51:33.629387 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:33.765250 [ 5110 ] {b7f70040-c1ef-4e9c-b70c-20f99603a70f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32'. Expected 1 argument, got 3 arguments: In scope SELECT toFloat32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1361, line 1364) (in query: SELECT toFloat32([], [], []);) 2025.06.13 15:51:33.779950 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32'. Expected 1 argument, got 3 arguments: In scope SELECT toFloat32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:33.920287 [ 5110 ] {05f94525-6df5-4e81-a9eb-7d9f1f076ab5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1362, line 1365) (in query: SELECT toFloat32OrDefault([], [], []);) 2025.06.13 15:51:33.954785 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:34.196722 [ 5110 ] {623ca23f-97a5-4fa4-9344-bab9da235832} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1363, line 1366) (in query: SELECT toFloat32OrNull([], [], []);) 2025.06.13 15:51:34.263677 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:34.573758 [ 5110 ] {59720e56-b6a8-481d-b1fc-e24564b9dd4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1364, line 1367) (in query: SELECT toFloat32OrZero([], [], []);) 2025.06.13 15:51:34.643077 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:34.916770 [ 5110 ] {1b46bfe4-25a0-4dec-8644-61d08bc155d5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64'. Expected 1 argument, got 3 arguments: In scope SELECT toFloat64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1365, line 1368) (in query: SELECT toFloat64([], [], []);) 2025.06.13 15:51:35.015836 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64'. Expected 1 argument, got 3 arguments: In scope SELECT toFloat64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:35.313333 [ 5110 ] {11286ea9-770f-4851-afd6-644c9a0c5383} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1366, line 1369) (in query: SELECT toFloat64OrDefault([], [], []);) 2025.06.13 15:51:35.390147 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:35.677664 [ 5110 ] {7662be45-1ce3-40bf-84a0-7de681428f7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1367, line 1370) (in query: SELECT toFloat64OrNull([], [], []);) 2025.06.13 15:51:35.726520 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:35.970089 [ 5110 ] {022585b2-baca-43c2-b247-7e80d7750b24} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1368, line 1371) (in query: SELECT toFloat64OrZero([], [], []);) 2025.06.13 15:51:36.043169 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:36.409182 [ 5110 ] {729ed389-3b2d-4db7-a503-4e906120e76f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 3, should be 1 or 2: In scope SELECT toHour([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1369, line 1372) (in query: SELECT toHour([], [], []);) 2025.06.13 15:51:36.425422 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 3, should be 1 or 2: In scope SELECT toHour([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:36.621760 [ 5110 ] {a7e094de-8e79-44a5-a7a2-0101fd680251} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4'. Expected 1 argument, got 3 arguments: In scope SELECT toIPv4([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1370, line 1373) (in query: SELECT toIPv4([], [], []);) 2025.06.13 15:51:36.654415 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4'. Expected 1 argument, got 3 arguments: In scope SELECT toIPv4([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:36.818470 [ 5110 ] {101dbc5a-c6a0-42d5-afed-f1eb52e058a7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1371, line 1374) (in query: SELECT toIPv4OrDefault([], [], []);) 2025.06.13 15:51:36.836672 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:36.975516 [ 5110 ] {b5506557-fdbc-424b-a26f-073240994d55} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv4OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1372, line 1375) (in query: SELECT toIPv4OrNull([], [], []);) 2025.06.13 15:51:37.002498 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv4OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:37.325012 [ 5110 ] {a34ff93a-c4ae-4203-81cd-786a477afda0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv4OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1373, line 1376) (in query: SELECT toIPv4OrZero([], [], []);) 2025.06.13 15:51:37.408902 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv4OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:37.487644 [ 5110 ] {fd4e0510-1ca4-451a-bd7e-661bbbc270d7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6'. Expected 1 argument, got 3 arguments: In scope SELECT toIPv6([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1374, line 1377) (in query: SELECT toIPv6([], [], []);) 2025.06.13 15:51:37.491482 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6'. Expected 1 argument, got 3 arguments: In scope SELECT toIPv6([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:37.651698 [ 5110 ] {3753799d-f11d-4f83-9f55-f5ed427d85e7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1375, line 1378) (in query: SELECT toIPv6OrDefault([], [], []);) 2025.06.13 15:51:37.657714 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:37.909501 [ 5110 ] {cb1cc8dc-c899-4b3f-a4c0-1b3304bc0f8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv6OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1376, line 1379) (in query: SELECT toIPv6OrNull([], [], []);) 2025.06.13 15:51:37.930038 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv6OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:38.100163 [ 5110 ] {6e8c7d9e-74e0-4d5b-92f5-f02f3750216a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv6OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1377, line 1380) (in query: SELECT toIPv6OrZero([], [], []);) 2025.06.13 15:51:38.103636 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv6OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:38.295919 [ 5110 ] {c08cbd12-6e22-4a54-87df-cbfd2ee03539} executeQuery: Code: 42. DB::Exception: Number of arguments for function toISOWeek doesn't match: passed 3, should be 1 or 2: In scope SELECT toISOWeek([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1378, line 1381) (in query: SELECT toISOWeek([], [], []);) 2025.06.13 15:51:38.332432 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toISOWeek doesn't match: passed 3, should be 1 or 2: In scope SELECT toISOWeek([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:38.558384 [ 5110 ] {74f4e2fd-ddae-4ad5-aad6-32f0bd9e8a60} executeQuery: Code: 42. DB::Exception: Number of arguments for function toISOYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toISOYear([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1379, line 1382) (in query: SELECT toISOYear([], [], []);) 2025.06.13 15:51:38.594329 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toISOYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toISOYear([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:38.682969 [ 5110 ] {9c02cbf8-514f-401b-864d-af9e750ba42b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128'. Expected 1 argument, got 3 arguments: In scope SELECT toInt128([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1380, line 1383) (in query: SELECT toInt128([], [], []);) 2025.06.13 15:51:38.724782 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128'. Expected 1 argument, got 3 arguments: In scope SELECT toInt128([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:38.772391 [ 5110 ] {a8745203-f359-4aee-bc15-c7e5591d722b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1381, line 1384) (in query: SELECT toInt128OrDefault([], [], []);) 2025.06.13 15:51:38.852266 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:39.017768 [ 5110 ] {393a3c7f-fb16-4ace-8de0-87ff84e7963b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1382, line 1385) (in query: SELECT toInt128OrNull([], [], []);) 2025.06.13 15:51:39.030211 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:39.092690 [ 5110 ] {9aae7eb7-104a-47c0-977d-d4cba5f62b24} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1383, line 1386) (in query: SELECT toInt128OrZero([], [], []);) 2025.06.13 15:51:39.097184 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:39.284143 [ 5110 ] {24815eb9-b7d6-48a1-a38a-ac75e6f0309a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16'. Expected 1 argument, got 3 arguments: In scope SELECT toInt16([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1384, line 1387) (in query: SELECT toInt16([], [], []);) 2025.06.13 15:51:39.324517 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16'. Expected 1 argument, got 3 arguments: In scope SELECT toInt16([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:39.600101 [ 5110 ] {e80bd775-dcb0-4f0f-8a8e-40ef3dae8395} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1385, line 1388) (in query: SELECT toInt16OrDefault([], [], []);) 2025.06.13 15:51:39.627049 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:40.144785 [ 5110 ] {8dbcdb03-68be-4c14-b027-944544b33447} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1386, line 1389) (in query: SELECT toInt16OrNull([], [], []);) 2025.06.13 15:51:40.159708 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:40.204288 [ 5110 ] {d43caa2c-cc87-447d-8a44-7ef58abbd929} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1387, line 1390) (in query: SELECT toInt16OrZero([], [], []);) 2025.06.13 15:51:40.221548 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:40.323552 [ 5110 ] {122ca214-5849-489f-9ebf-48ed2d53eea0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256'. Expected 1 argument, got 3 arguments: In scope SELECT toInt256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1388, line 1391) (in query: SELECT toInt256([], [], []);) 2025.06.13 15:51:40.327013 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256'. Expected 1 argument, got 3 arguments: In scope SELECT toInt256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:40.503946 [ 5110 ] {9c8d35e5-ae4c-4b1d-b976-2ca5828c41fa} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1389, line 1392) (in query: SELECT toInt256OrDefault([], [], []);) 2025.06.13 15:51:40.583259 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:41.036060 [ 5110 ] {72b02c28-9f20-4d6d-8254-0b8a027f1645} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1390, line 1393) (in query: SELECT toInt256OrNull([], [], []);) 2025.06.13 15:51:41.070467 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:41.283208 [ 5110 ] {5b2c0470-ceae-4d5c-b9da-33c9ca6db852} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1391, line 1394) (in query: SELECT toInt256OrZero([], [], []);) 2025.06.13 15:51:41.292617 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:41.336503 [ 5110 ] {aa602ddc-2170-49e7-9110-6b40ec79bbf2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32'. Expected 1 argument, got 3 arguments: In scope SELECT toInt32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1392, line 1395) (in query: SELECT toInt32([], [], []);) 2025.06.13 15:51:41.341942 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32'. Expected 1 argument, got 3 arguments: In scope SELECT toInt32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:41.493501 [ 5110 ] {2643a801-353a-451c-9f9a-ae050ffd8204} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1393, line 1396) (in query: SELECT toInt32OrDefault([], [], []);) 2025.06.13 15:51:41.509849 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:41.673575 [ 5110 ] {9b17edb5-4732-45fd-a9da-b6fb3d7185e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1394, line 1397) (in query: SELECT toInt32OrNull([], [], []);) 2025.06.13 15:51:41.697003 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:42.117703 [ 5110 ] {b5e2fecc-c62c-4dc4-88f5-e6877a69dd83} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1395, line 1398) (in query: SELECT toInt32OrZero([], [], []);) 2025.06.13 15:51:42.139366 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:42.196499 [ 5110 ] {8fe95323-11fb-4168-9ccd-844c0763c1ba} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64'. Expected 1 argument, got 3 arguments: In scope SELECT toInt64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1396, line 1399) (in query: SELECT toInt64([], [], []);) 2025.06.13 15:51:42.248161 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64'. Expected 1 argument, got 3 arguments: In scope SELECT toInt64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:42.422851 [ 5110 ] {ea15678e-129c-4cef-a41a-9d50a711f21a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1397, line 1400) (in query: SELECT toInt64OrDefault([], [], []);) 2025.06.13 15:51:42.454496 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:42.576229 [ 5110 ] {96d3cb7b-3ddc-428c-9aa7-01d4a63d24b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1398, line 1401) (in query: SELECT toInt64OrNull([], [], []);) 2025.06.13 15:51:42.647735 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:42.932693 [ 5110 ] {33a2b8a3-2da4-437d-aac9-8f4e93cfe8e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1399, line 1402) (in query: SELECT toInt64OrZero([], [], []);) 2025.06.13 15:51:42.956832 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:43.186125 [ 5110 ] {6cdcac1a-6361-4dd0-a25a-ad8338c11e52} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8'. Expected 1 argument, got 3 arguments: In scope SELECT toInt8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1400, line 1403) (in query: SELECT toInt8([], [], []);) 2025.06.13 15:51:43.190495 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8'. Expected 1 argument, got 3 arguments: In scope SELECT toInt8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:43.413691 [ 5110 ] {928f8c6b-6172-42d8-af7c-bf39dcb00b1d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1401, line 1404) (in query: SELECT toInt8OrDefault([], [], []);) 2025.06.13 15:51:43.420072 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:43.593642 [ 5110 ] {f1be32a0-603c-44ce-aea4-1e8bf6d7bdc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt8OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1402, line 1405) (in query: SELECT toInt8OrNull([], [], []);) 2025.06.13 15:51:43.643511 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt8OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:43.875539 [ 5110 ] {01b70642-52bf-4020-bdd2-969f745f057b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt8OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1403, line 1406) (in query: SELECT toInt8OrZero([], [], []);) 2025.06.13 15:51:43.890301 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt8OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:44.102664 [ 5110 ] {74b08ca5-f386-4aa5-a15f-53a2930bca12} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalDay'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalDay([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1404, line 1407) (in query: SELECT toIntervalDay([], [], []);) 2025.06.13 15:51:44.168767 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalDay'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalDay([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:44.654228 [ 5110 ] {96bd075a-1b4a-43bb-bf06-ef568689e5aa} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalHour'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalHour([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1405, line 1408) (in query: SELECT toIntervalHour([], [], []);) 2025.06.13 15:51:44.767856 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalHour'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalHour([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:45.145174 [ 5110 ] {36cb7d97-4ebf-4bc0-aef8-509273b08ce3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMicrosecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMicrosecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1406, line 1409) (in query: SELECT toIntervalMicrosecond([], [], []);) 2025.06.13 15:51:45.381646 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMicrosecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMicrosecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:45.886340 [ 5110 ] {88a347eb-ad00-4a0b-89bd-094fb5f517f4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMillisecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMillisecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1407, line 1410) (in query: SELECT toIntervalMillisecond([], [], []);) 2025.06.13 15:51:45.903029 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMillisecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMillisecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:46.151421 [ 5110 ] {ef0b9247-ca33-4d9c-857e-d90589f4a6cd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMinute'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMinute([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1408, line 1411) (in query: SELECT toIntervalMinute([], [], []);) 2025.06.13 15:51:46.184480 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMinute'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMinute([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:46.392702 [ 5110 ] {329c910f-03c0-40a2-b9cb-28af71d89034} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMonth'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMonth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1409, line 1412) (in query: SELECT toIntervalMonth([], [], []);) 2025.06.13 15:51:46.436386 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMonth'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMonth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:46.543157 [ 5110 ] {c7487f2c-6093-4124-b952-9501d1d5755c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalNanosecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalNanosecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1410, line 1413) (in query: SELECT toIntervalNanosecond([], [], []);) 2025.06.13 15:51:46.561720 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalNanosecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalNanosecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:46.647700 [ 5110 ] {dca68b8d-08f3-4113-b5ef-c919e8e46e8a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalQuarter'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalQuarter([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1411, line 1414) (in query: SELECT toIntervalQuarter([], [], []);) 2025.06.13 15:51:46.668852 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalQuarter'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalQuarter([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:47.308331 [ 5110 ] {7d3dead2-bdb7-4861-a70b-428255748f55} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalSecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalSecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1412, line 1415) (in query: SELECT toIntervalSecond([], [], []);) 2025.06.13 15:51:47.348323 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalSecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalSecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:47.784463 [ 5110 ] {a81a20e6-882c-434d-b78b-7e2f3ffba5d8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalWeek'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalWeek([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1413, line 1416) (in query: SELECT toIntervalWeek([], [], []);) 2025.06.13 15:51:47.912459 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalWeek'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalWeek([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:48.179963 [ 5110 ] {b5b151f6-4ef8-4651-8fe1-2143d5f2480d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalYear'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalYear([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1414, line 1417) (in query: SELECT toIntervalYear([], [], []);) 2025.06.13 15:51:48.221959 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalYear'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalYear([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:48.355179 [ 5110 ] {b7138f59-68f4-4e8c-a638-3e92478508e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1415, line 1418) (in query: SELECT toJSONString([], [], []);) 2025.06.13 15:51:48.381661 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:48.570286 [ 5110 ] {8fd2ed9c-9b41-43ce-976b-73e66b09a8ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toLastDayOfMonth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1416, line 1419) (in query: SELECT toLastDayOfMonth([], [], []);) 2025.06.13 15:51:48.633577 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toLastDayOfMonth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:48.796210 [ 5110 ] {bc33a95e-6da8-400c-ad15-98cd320c5374} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toLastDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toLastDayOfWeek([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1417, line 1420) (in query: SELECT toLastDayOfWeek([], [], []);) 2025.06.13 15:51:48.818459 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toLastDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toLastDayOfWeek([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:48.966823 [ 5110 ] {db40d48d-96f1-49ad-9bb2-4e0fc5b6d5e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1418, line 1421) (in query: SELECT toLowCardinality([], [], []);) 2025.06.13 15:51:49.006784 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:49.169246 [ 5110 ] {ec66e340-25e4-421d-9d81-65a2ba71cad4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toMillisecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1419, line 1422) (in query: SELECT toMillisecond([], [], []);) 2025.06.13 15:51:49.174500 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toMillisecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:49.410068 [ 5110 ] {9886e51c-8185-4b97-819d-2ba589e74b9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT toMinute([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1420, line 1423) (in query: SELECT toMinute([], [], []);) 2025.06.13 15:51:49.422527 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT toMinute([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:49.491280 [ 5110 ] {5fd90b65-ab89-4afc-9597-a622e77aeef5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1421, line 1424) (in query: SELECT toModifiedJulianDay([], [], []);) 2025.06.13 15:51:49.504727 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:49.792915 [ 5110 ] {85cfa2de-855b-4fa8-85c0-0e990e8883cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1422, line 1425) (in query: SELECT toModifiedJulianDayOrNull([], [], []);) 2025.06.13 15:51:49.821666 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:49.919718 [ 5110 ] {259ead05-0bbd-4b36-85f0-4fe9447dd70a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonday doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonday([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1423, line 1426) (in query: SELECT toMonday([], [], []);) 2025.06.13 15:51:49.950701 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonday doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonday([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:50.454532 [ 5110 ] {faf5b3a5-695c-4a8e-9e72-1826a4050947} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1424, line 1427) (in query: SELECT toMonth([], [], []);) 2025.06.13 15:51:50.495359 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:51.016798 [ 5110 ] {2ae6b5bf-2316-4fe3-a811-bb9ca268d641} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonthNumSinceEpoch doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonthNumSinceEpoch([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1425, line 1428) (in query: SELECT toMonthNumSinceEpoch([], [], []);) 2025.06.13 15:51:51.109881 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonthNumSinceEpoch doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonthNumSinceEpoch([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:51.318608 [ 5110 ] {9acc3242-725c-4bc3-a622-48a0e8858e82} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1426, line 1429) (in query: SELECT toNullable([], [], []);) 2025.06.13 15:51:51.412009 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:51.587655 [ 7279 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:51:51.600113 [ 5110 ] {efb71468-db0b-42b8-9a5d-006bd92df351} executeQuery: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT toQuarter([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1427, line 1430) (in query: SELECT toQuarter([], [], []);) 2025.06.13 15:51:51.672759 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT toQuarter([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:52.001484 [ 5110 ] {b74b0be5-7ec2-46a6-bea0-5861d57bbcd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeDayNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeDayNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1428, line 1431) (in query: SELECT toRelativeDayNum([], [], []);) 2025.06.13 15:51:52.098790 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeDayNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeDayNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:52.184946 [ 5110 ] {f86c52aa-21f1-41f5-a785-0b5281f0f9a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeHourNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeHourNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1429, line 1432) (in query: SELECT toRelativeHourNum([], [], []);) 2025.06.13 15:51:52.212319 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeHourNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeHourNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:52.490865 [ 5110 ] {4db16d82-ce29-40e9-ae2e-dbbc6837a568} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeMinuteNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeMinuteNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1430, line 1433) (in query: SELECT toRelativeMinuteNum([], [], []);) 2025.06.13 15:51:52.586517 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeMinuteNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeMinuteNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:52.642026 [ 5110 ] {93e4d133-ab07-4e37-a442-dba04623b10b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeMonthNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeMonthNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1431, line 1434) (in query: SELECT toRelativeMonthNum([], [], []);) 2025.06.13 15:51:52.674109 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeMonthNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeMonthNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:52.968189 [ 5110 ] {0b0582ba-c29a-43c7-b9dc-4732adb0bb02} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeQuarterNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeQuarterNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1432, line 1435) (in query: SELECT toRelativeQuarterNum([], [], []);) 2025.06.13 15:51:52.993596 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeQuarterNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeQuarterNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:53.066977 [ 5110 ] {eab50ea3-2518-458a-a2fc-3869a3a55135} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeSecondNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeSecondNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1433, line 1436) (in query: SELECT toRelativeSecondNum([], [], []);) 2025.06.13 15:51:53.138646 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeSecondNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeSecondNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:53.317660 [ 5110 ] {eea2116f-43be-43b1-825c-e35d5344b10e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeWeekNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeWeekNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1434, line 1437) (in query: SELECT toRelativeWeekNum([], [], []);) 2025.06.13 15:51:53.368930 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeWeekNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeWeekNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:53.679082 [ 5110 ] {4de3254f-a21b-4b1d-bee7-7648980fd65a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeYearNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeYearNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1435, line 1438) (in query: SELECT toRelativeYearNum([], [], []);) 2025.06.13 15:51:53.700445 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeYearNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeYearNum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:53.841134 [ 5110 ] {36ebf457-0b7d-44e9-9961-f3c2475f4431} executeQuery: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toSecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1436, line 1439) (in query: SELECT toSecond([], [], []);) 2025.06.13 15:51:53.850190 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toSecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:54.062656 [ 5110 ] {110a33c0-7ab3-42da-b6e5-043d362c817c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfDay doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfDay([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1437, line 1440) (in query: SELECT toStartOfDay([], [], []);) 2025.06.13 15:51:54.108390 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfDay doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfDay([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:54.383427 [ 5110 ] {71411a0b-479c-40b2-93db-a6fbd0737384} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFifteenMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFifteenMinutes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1438, line 1441) (in query: SELECT toStartOfFifteenMinutes([], [], []);) 2025.06.13 15:51:54.411262 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFifteenMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFifteenMinutes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:54.790092 [ 5110 ] {fd7e2623-c57b-4d13-8b33-06a352ba931c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFiveMinute([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1439, line 1442) (in query: SELECT toStartOfFiveMinute([], [], []);) 2025.06.13 15:51:54.802684 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFiveMinute([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:54.986188 [ 5110 ] {1f702d2f-20a6-4d99-9d0d-346fe30340fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFiveMinutes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1440, line 1443) (in query: SELECT toStartOfFiveMinutes([], [], []);) 2025.06.13 15:51:54.989712 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFiveMinutes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:55.231596 [ 5110 ] {340607e6-664b-408a-918a-500a18e22578} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfHour doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfHour([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1441, line 1444) (in query: SELECT toStartOfHour([], [], []);) 2025.06.13 15:51:55.305017 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfHour doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfHour([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:55.541524 [ 5110 ] {0bcf5c6b-5fce-4b73-9a88-30fee1d00447} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfISOYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfISOYear([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1442, line 1445) (in query: SELECT toStartOfISOYear([], [], []);) 2025.06.13 15:51:55.581270 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfISOYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfISOYear([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:55.769505 [ 5110 ] {32d86ec5-97e9-4bc9-b6ba-132226d030b5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toStartOfInterval, expected a Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfInterval([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1443, line 1446) (in query: SELECT toStartOfInterval([], [], []);) 2025.06.13 15:51:55.792483 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toStartOfInterval, expected a Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfInterval([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:55.931283 [ 5110 ] {c0da118e-78af-4e2d-9aef-d008fa03bbd3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMicrosecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMicrosecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1444, line 1447) (in query: SELECT toStartOfMicrosecond([], [], []);) 2025.06.13 15:51:55.946286 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMicrosecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMicrosecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:56.189672 [ 5110 ] {2af300a7-b809-4d22-aaaa-51a18aabf8eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMillisecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1445, line 1448) (in query: SELECT toStartOfMillisecond([], [], []);) 2025.06.13 15:51:56.197376 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMillisecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:56.472457 [ 5110 ] {1b41ff0b-2195-4e2a-8bf7-59b3a89a767d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMinute([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1446, line 1449) (in query: SELECT toStartOfMinute([], [], []);) 2025.06.13 15:51:56.529751 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMinute([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:57.034194 [ 5110 ] {33a93218-04a7-4071-b0f5-5df3a82fdcaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMonth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1447, line 1450) (in query: SELECT toStartOfMonth([], [], []);) 2025.06.13 15:51:57.042884 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMonth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:57.099749 [ 5110 ] {c3e838c8-1752-4dae-a80e-c9f3ce8f3154} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfNanosecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfNanosecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1448, line 1451) (in query: SELECT toStartOfNanosecond([], [], []);) 2025.06.13 15:51:57.121691 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfNanosecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfNanosecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:57.212823 [ 5110 ] {16f7ffcb-0623-4a8b-a31c-f9377e3418f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfQuarter([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1449, line 1452) (in query: SELECT toStartOfQuarter([], [], []);) 2025.06.13 15:51:57.268822 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfQuarter([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:57.612332 [ 5110 ] {d56ac549-a812-4d19-b82a-8341454033ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfSecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1450, line 1453) (in query: SELECT toStartOfSecond([], [], []);) 2025.06.13 15:51:57.711925 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfSecond([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:58.168452 [ 5110 ] {213713d0-e9c4-4eaf-b468-3cf94dedea10} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfTenMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfTenMinutes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1451, line 1454) (in query: SELECT toStartOfTenMinutes([], [], []);) 2025.06.13 15:51:58.172986 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfTenMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfTenMinutes([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:58.499551 [ 5110 ] {2f010a04-d236-4daf-898c-9c5089a793f0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfWeek([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1452, line 1455) (in query: SELECT toStartOfWeek([], [], []);) 2025.06.13 15:51:58.577256 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfWeek([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:51:58.870730 [ 5110 ] {eb93c5cb-197e-4847-8857-ae0ee9f5fbd5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfYear([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1453, line 1456) (in query: SELECT toStartOfYear([], [], []);) 2025.06.13 15:51:58.883931 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfYear([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:59.065928 [ 5110 ] {0c015f08-96b7-4a38-a2fc-dc3094b1bea5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toString'. Expected 1 argument, got 3 arguments: In scope SELECT toString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1454, line 1457) (in query: SELECT toString([], [], []);) 2025.06.13 15:51:59.118876 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toString'. Expected 1 argument, got 3 arguments: In scope SELECT toString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:59.360710 [ 5110 ] {55f937da-0dbf-499e-90e0-9c1ff59d44bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1455, line 1458) (in query: SELECT toStringCutToZero([], [], []);) 2025.06.13 15:51:59.441270 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:59.672520 [ 5110 ] {bdc99069-e02b-4b6c-92af-78ef8497bd9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTime doesn't match: passed 3, should be 1 or 2: In scope SELECT toTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1456, line 1459) (in query: SELECT toTime([], [], []);) 2025.06.13 15:51:59.739608 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTime doesn't match: passed 3, should be 1 or 2: In scope SELECT toTime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:51:59.870218 [ 5110 ] {b73d65ec-3d6d-4018-bac1-2a7c6658efb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1457, line 1460) (in query: SELECT toTimeZone([], [], []);) 2025.06.13 15:51:59.935944 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:00.235115 [ 5110 ] {6c6a43e5-b8a8-4690-bbfa-7df6e942f2f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1458, line 1461) (in query: SELECT toTimezone([], [], []);) 2025.06.13 15:52:00.279402 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:00.618541 [ 5110 ] {f2374028-0227-4ad0-b700-c1e57340f1be} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1459, line 1462) (in query: SELECT toTypeName([], [], []);) 2025.06.13 15:52:00.622517 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:00.787185 [ 5110 ] {b9a25566-3ee6-403f-a095-802110dfa101} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt128([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1460, line 1463) (in query: SELECT toUInt128([], [], []);) 2025.06.13 15:52:00.801337 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt128([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:00.938534 [ 5110 ] {7ba4144d-86c7-45ef-a61d-dacaefcc33d9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1461, line 1464) (in query: SELECT toUInt128OrDefault([], [], []);) 2025.06.13 15:52:00.983937 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:01.044509 [ 5110 ] {b06dfcf4-33a5-4920-b34e-1359a6b3265e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1462, line 1465) (in query: SELECT toUInt128OrNull([], [], []);) 2025.06.13 15:52:01.080160 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:01.243934 [ 5110 ] {882e4b97-99d5-41c2-b532-64ae37b494a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1463, line 1466) (in query: SELECT toUInt128OrZero([], [], []);) 2025.06.13 15:52:01.249124 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:01.348687 [ 5110 ] {c3413eb9-afee-4f62-b6a0-c4cb10a6880e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt16([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1464, line 1467) (in query: SELECT toUInt16([], [], []);) 2025.06.13 15:52:01.353076 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt16([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:01.442562 [ 5110 ] {539741cb-3874-4725-ba68-e88f8bd89b3b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1465, line 1468) (in query: SELECT toUInt16OrDefault([], [], []);) 2025.06.13 15:52:01.470992 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:01.564576 [ 5110 ] {5e1ad47a-90d8-435f-9c94-a9e276f7434d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1466, line 1469) (in query: SELECT toUInt16OrNull([], [], []);) 2025.06.13 15:52:01.611774 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:01.846262 [ 5110 ] {044ab93a-922e-4aa9-8421-e3aa653e687a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1467, line 1470) (in query: SELECT toUInt16OrZero([], [], []);) 2025.06.13 15:52:01.879355 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:02.027288 [ 5110 ] {1304242d-0aa7-44e4-8662-e25d3ca6a0e9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1468, line 1471) (in query: SELECT toUInt256([], [], []);) 2025.06.13 15:52:02.113600 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt256([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:02.276564 [ 5110 ] {c03dccd6-560e-4cf9-9081-4e6b43302534} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1469, line 1472) (in query: SELECT toUInt256OrDefault([], [], []);) 2025.06.13 15:52:02.286658 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:02.535619 [ 3501 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {322eb610-7231-45f1-872a-f605008de98e::202506_1_132_32}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab57af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab1fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003122f56b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d8e4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:02.661324 [ 5110 ] {9d3a8589-40c6-4076-b7bc-1ee6d5779799} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1470, line 1473) (in query: SELECT toUInt256OrNull([], [], []);) 2025.06.13 15:52:02.665821 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:02.734570 [ 5110 ] {3d8e39d3-2959-41b4-908b-6abc766765c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1471, line 1474) (in query: SELECT toUInt256OrZero([], [], []);) 2025.06.13 15:52:02.748430 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:02.853919 [ 5110 ] {d4c62741-9861-4f3e-aca0-5456db17fa1a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1472, line 1475) (in query: SELECT toUInt32([], [], []);) 2025.06.13 15:52:02.858998 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt32([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:03.084959 [ 5110 ] {36de13e1-6ed0-41a4-bfcd-9c1410e38969} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1473, line 1476) (in query: SELECT toUInt32OrDefault([], [], []);) 2025.06.13 15:52:03.098116 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:03.195892 [ 5110 ] {74ea3cd4-9d16-414e-b4c9-b4e43e22f6f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1474, line 1477) (in query: SELECT toUInt32OrNull([], [], []);) 2025.06.13 15:52:03.212218 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:03.316554 [ 5110 ] {31e95384-f39c-461f-92c8-b46c1b3bfb37} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1475, line 1478) (in query: SELECT toUInt32OrZero([], [], []);) 2025.06.13 15:52:03.408048 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:03.920138 [ 5110 ] {d7bd44de-630a-474d-9c1e-531175cfdeec} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1476, line 1479) (in query: SELECT toUInt64([], [], []);) 2025.06.13 15:52:03.996845 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt64([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:04.312789 [ 5110 ] {b6c00fd1-69b5-4437-aac1-7092bc11ac3c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1477, line 1480) (in query: SELECT toUInt64OrDefault([], [], []);) 2025.06.13 15:52:04.397846 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:04.664724 [ 5110 ] {edb129d9-f12b-4314-ad44-1e0aa38844a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1478, line 1481) (in query: SELECT toUInt64OrNull([], [], []);) 2025.06.13 15:52:04.714668 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:04.863222 [ 5110 ] {b0e17501-c710-459b-9f13-211fb42e5ecb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1479, line 1482) (in query: SELECT toUInt64OrZero([], [], []);) 2025.06.13 15:52:04.878701 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:05.068714 [ 5110 ] {78af5425-6a4d-4cbc-ab20-ad58017e6339} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1480, line 1483) (in query: SELECT toUInt8([], [], []);) 2025.06.13 15:52:05.090352 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:05.247823 [ 5110 ] {167c2fb9-f001-4714-819b-a1f17ffc7dbf} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1481, line 1484) (in query: SELECT toUInt8OrDefault([], [], []);) 2025.06.13 15:52:05.303618 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:05.430780 [ 5110 ] {8d8ae354-4573-49b4-8ef0-6199b17a7015} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt8OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1482, line 1485) (in query: SELECT toUInt8OrNull([], [], []);) 2025.06.13 15:52:05.434721 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt8OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:05.533731 [ 5110 ] {f1a71db2-f279-4e6b-9666-f6f91e785b5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt8OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1483, line 1486) (in query: SELECT toUInt8OrZero([], [], []);) 2025.06.13 15:52:05.546221 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt8OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:05.994701 [ 5110 ] {58a4a325-b574-4c11-a7d8-1726634435ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1484, line 1487) (in query: SELECT toUTCTimestamp([], [], []);) 2025.06.13 15:52:05.999398 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:06.059692 [ 5110 ] {b5fe750d-8a59-4794-be1a-19e0403b34b6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUID'. Expected 1 argument, got 3 arguments: In scope SELECT toUUID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1485, line 1488) (in query: SELECT toUUID([], [], []);) 2025.06.13 15:52:06.070270 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUID'. Expected 1 argument, got 3 arguments: In scope SELECT toUUID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:06.391625 [ 5110 ] {41bcd661-68b2-4808-a606-81e886e565e2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1486, line 1489) (in query: SELECT toUUIDOrDefault([], [], []);) 2025.06.13 15:52:06.447420 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:06.786016 [ 5110 ] {4e6268ed-bb63-427d-96ac-7678a0576acd} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUUIDOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1487, line 1490) (in query: SELECT toUUIDOrNull([], [], []);) 2025.06.13 15:52:06.840979 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUUIDOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrNull([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:07.122988 [ 5110 ] {8e84f8c3-957d-4292-a459-3428b7acba0d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUUIDOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1488, line 1491) (in query: SELECT toUUIDOrZero([], [], []);) 2025.06.13 15:52:07.129084 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUUIDOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:07.324522 [ 5110 ] {05e74c51-8ed4-44b0-844a-c71a147edaea} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUnixTimestamp'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUnixTimestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1489, line 1492) (in query: SELECT toUnixTimestamp([], [], []);) 2025.06.13 15:52:07.352014 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUnixTimestamp'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUnixTimestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:07.461716 [ 5110 ] {2d69dca9-b30a-45ca-9d5f-f262ecb748fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1490, line 1493) (in query: SELECT toUnixTimestamp64Micro([], [], []);) 2025.06.13 15:52:07.556278 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:07.903605 [ 5110 ] {bd560939-c595-44c1-8bd6-8b537b84142d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1491, line 1494) (in query: SELECT toUnixTimestamp64Milli([], [], []);) 2025.06.13 15:52:07.979581 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:08.205571 [ 5110 ] {873e1424-ba3c-4aad-a9e0-c5b67ee5522e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1492, line 1495) (in query: SELECT toUnixTimestamp64Nano([], [], []);) 2025.06.13 15:52:08.264356 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:08.575449 [ 5110 ] {4315d7ad-c69b-4ec9-8f56-467b1fd27bf3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Second([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1493, line 1496) (in query: SELECT toUnixTimestamp64Second([], [], []);) 2025.06.13 15:52:08.604533 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Second([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:08.838052 [ 5110 ] {af812b5c-fd42-4a70-b9f7-589cf4acd940} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1494, line 1497) (in query: SELECT toValidUTF8([], [], []);) 2025.06.13 15:52:08.867674 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:09.215595 [ 5110 ] {c567d5fe-8c65-4763-a8da-e76dad5fd1f4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toWeek([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1495, line 1498) (in query: SELECT toWeek([], [], []);) 2025.06.13 15:52:09.220060 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toWeek([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:09.429202 [ 5110 ] {82f5d500-1ef4-4ac4-b1b4-44d1171b63f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMM doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMM([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1496, line 1499) (in query: SELECT toYYYYMM([], [], []);) 2025.06.13 15:52:09.476279 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMM doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMM([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:09.670273 [ 5110 ] {b298268f-add2-4942-a3b9-ef5b96a952a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDD doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMMDD([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1497, line 1500) (in query: SELECT toYYYYMMDD([], [], []);) 2025.06.13 15:52:09.694380 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDD doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMMDD([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:10.133051 [ 5110 ] {b547db63-0c7a-4a33-a84f-fb15d065bef0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDDhhmmss doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMMDDhhmmss([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1498, line 1501) (in query: SELECT toYYYYMMDDhhmmss([], [], []);) 2025.06.13 15:52:10.173704 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDDhhmmss doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMMDDhhmmss([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:10.401385 [ 5110 ] {066dbc53-3820-481d-a489-845097602173} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toYear([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1499, line 1502) (in query: SELECT toYear([], [], []);) 2025.06.13 15:52:10.415102 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toYear([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:10.714354 [ 5110 ] {a44cdd9e-ec03-4c0b-bf32-137452dc97f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYearNumSinceEpoch doesn't match: passed 3, should be 1 or 2: In scope SELECT toYearNumSinceEpoch([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1500, line 1503) (in query: SELECT toYearNumSinceEpoch([], [], []);) 2025.06.13 15:52:10.737011 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYearNumSinceEpoch doesn't match: passed 3, should be 1 or 2: In scope SELECT toYearNumSinceEpoch([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:10.885544 [ 5110 ] {2447f1fa-d0f3-4582-982c-e8942e464787} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toYearWeek([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1501, line 1504) (in query: SELECT toYearWeek([], [], []);) 2025.06.13 15:52:10.911672 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toYearWeek([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:11.138396 [ 5110 ] {05ef68fc-594d-4f23-a033-0240ca2a9e9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1502, line 1505) (in query: SELECT to_utc_timestamp([], [], []);) 2025.06.13 15:52:11.211711 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:11.376526 [ 5110 ] {0563bbf0-365e-44c5-9299-e2c0af2a914c} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1503, line 1506) (in query: SELECT today([], [], []);) 2025.06.13 15:52:11.442151 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:11.698413 [ 5110 ] {f68d2f14-0c2c-411b-9ae2-2da6110d1a2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1504, line 1507) (in query: SELECT tokens([], [], []);) 2025.06.13 15:52:11.771587 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:11.922684 [ 5110 ] {4cbdd846-9adf-40a2-9bbb-2b14d2ba2618} executeQuery: Code: 42. DB::Exception: Aggregate function topK requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1505, line 1508) (in query: SELECT topK([], [], []);) 2025.06.13 15:52:11.938267 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function topK requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:12.129676 [ 5110 ] {bf22a53a-31f5-478f-b35b-4cdae3b75dda} executeQuery: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1506, line 1509) (in query: SELECT topKWeighted([], [], []);) 2025.06.13 15:52:12.134570 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:12.245247 [ 5110 ] {1b821497-18d5-4bf6-ae83-287d09002613} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1507, line 1510) (in query: SELECT topLevelDomain([], [], []);) 2025.06.13 15:52:12.249236 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:12.370046 [ 5110 ] {b6d52a03-3df5-43c3-9cd9-b8f4372eca4c} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1508, line 1511) (in query: SELECT topLevelDomainRFC([], [], []);) 2025.06.13 15:52:12.380361 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:12.730057 [ 5110 ] {8bf9ac6e-e97c-42e8-8f29-e195734b7276} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1509, line 1512) (in query: SELECT transactionID([], [], []);) 2025.06.13 15:52:12.759193 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:12.828465 [ 5110 ] {212901b7-ac95-419d-9e96-108f1d1322d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1510, line 1513) (in query: SELECT transactionLatestSnapshot([], [], []);) 2025.06.13 15:52:12.873101 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:12.979656 [ 5110 ] {002f4dd1-04d7-4c5e-b554-c814d7f70a77} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1511, line 1514) (in query: SELECT transactionOldestSnapshot([], [], []);) 2025.06.13 15:52:13.005502 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:13.341731 [ 5110 ] {8c7b7f74-59a1-4d53-a22b-a288bb9abe76} executeQuery: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope SELECT transform([], [], []). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1512, line 1515) (in query: SELECT transform([], [], []);) 2025.06.13 15:52:13.410016 [ 5110 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope SELECT transform([], [], []). (BAD_ARGUMENTS) 2025.06.13 15:52:13.793069 [ 5110 ] {0a9e8473-6e00-4058-a863-7d26d81a58f3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function translate: In scope SELECT translate([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1513, line 1516) (in query: SELECT translate([], [], []);) 2025.06.13 15:52:13.814716 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function translate: In scope SELECT translate([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:13.892357 [ 5110 ] {42c93fd3-62ba-4564-882e-5b1a1ba49cf4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function translateUTF8: In scope SELECT translateUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1514, line 1517) (in query: SELECT translateUTF8([], [], []);) 2025.06.13 15:52:13.906271 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function translateUTF8: In scope SELECT translateUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:14.022404 [ 5110 ] {0bdd0b6d-0e23-42b9-ba86-83dfa17e83b3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimBoth'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trimBoth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1515, line 1519) (in query: SELECT trimBoth([], [], []);) 2025.06.13 15:52:14.042701 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimBoth'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trimBoth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:14.305833 [ 5110 ] {717e8712-2682-4f95-8173-b7ce044558b5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimLeft'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trimLeft([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1516, line 1520) (in query: SELECT trimLeft([], [], []);) 2025.06.13 15:52:14.414442 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimLeft'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trimLeft([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:14.752755 [ 5110 ] {dac200e3-b57a-4c8f-beb5-826c23793ae7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimRight'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trimRight([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1517, line 1521) (in query: SELECT trimRight([], [], []);) 2025.06.13 15:52:14.814289 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimRight'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trimRight([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:14.945507 [ 5110 ] {e6d515da-9271-4c24-a8c1-71cd02c97b65} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trunc([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1518, line 1522) (in query: SELECT trunc([], [], []);) 2025.06.13 15:52:15.042830 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trunc([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:15.161049 [ 5110 ] {c49767c8-9000-497c-a28e-7acfb53116cc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT truncate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1519, line 1523) (in query: SELECT truncate([], [], []);) 2025.06.13 15:52:15.196385 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT truncate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:15.395717 [ 5110 ] {275b4409-6f49-4945-9a1e-f21402aa3dad} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1520, line 1524) (in query: SELECT tryBase58Decode([], [], []);) 2025.06.13 15:52:15.422750 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:15.511710 [ 5110 ] {effba1f4-9214-432b-987c-3d496f818e98} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1521, line 1525) (in query: SELECT tryBase64Decode([], [], []);) 2025.06.13 15:52:15.518584 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:15.660583 [ 5110 ] {a4b695d5-a177-4b11-9dcf-29e31017f4df} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1522, line 1526) (in query: SELECT tryBase64URLDecode([], [], []);) 2025.06.13 15:52:15.665612 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:15.780121 [ 5110 ] {bab86886-1738-4e61-9371-ee9cccb45423} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'tryDecrypt'. Expected: decryption mode string, got: Array(Nothing): In scope SELECT tryDecrypt([], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1523, line 1527) (in query: SELECT tryDecrypt([], '[HIDDEN]')) 2025.06.13 15:52:15.783991 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'tryDecrypt'. Expected: decryption mode string, got: Array(Nothing): In scope SELECT tryDecrypt([], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:15.912280 [ 5110 ] {f1957981-d66c-4378-937d-6dc3b88e27fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1524, line 1528) (in query: SELECT tryIdnaEncode([], [], []);) 2025.06.13 15:52:15.929968 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:16.015043 [ 5110 ] {d934465f-998b-4504-8dfd-1a8ef69e8671} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1525, line 1529) (in query: SELECT tryPunycodeDecode([], [], []);) 2025.06.13 15:52:16.055634 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:16.133124 [ 5110 ] {cca3d104-6ddc-4ca4-8a57-c2973f02c3e6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tumble. Should be a date with time: In scope SELECT tumble([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1526, line 1530) (in query: SELECT tumble([], [], []);) 2025.06.13 15:52:16.136795 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tumble. Should be a date with time: In scope SELECT tumble([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:16.249298 [ 5110 ] {1c091202-9f3f-4b51-8f0e-f5809996c69c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tumbleEnd. Should be a date with time: In scope SELECT tumbleEnd([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1527, line 1531) (in query: SELECT tumbleEnd([], [], []);) 2025.06.13 15:52:16.253292 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tumbleEnd. Should be a date with time: In scope SELECT tumbleEnd([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:16.403324 [ 5110 ] {d53d40de-6180-42e5-9fdb-420e0d6efd8b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tumbleStart. Should be a date with time: In scope SELECT tumbleStart([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1528, line 1532) (in query: SELECT tumbleStart([], [], []);) 2025.06.13 15:52:16.424114 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tumbleStart. Should be a date with time: In scope SELECT tumbleStart([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:17.049425 [ 5110 ] {44c05525-fb04-4088-956d-6c9d930cdb09} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function tupleConcat: In scope SELECT tupleConcat([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1530, line 1534) (in query: SELECT tupleConcat([], [], []);) 2025.06.13 15:52:17.072877 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function tupleConcat: In scope SELECT tupleConcat([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:17.238785 [ 5110 ] {3ae1ca9c-2cfb-4f98-b9dd-0e9f3dd0beee} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1531, line 1535) (in query: SELECT tupleDivide([], [], []);) 2025.06.13 15:52:17.272738 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:17.489284 [ 5110 ] {dd48a02e-df1e-40f4-8b10-277f7a923792} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1532, line 1536) (in query: SELECT tupleDivideByNumber([], [], []);) 2025.06.13 15:52:17.511354 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:17.583260 [ 5110 ] {98ba1a04-518f-4a81-8dc6-5466f5f0b85a} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Array(Nothing): In scope SELECT tupleElement([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1533, line 1537) (in query: SELECT tupleElement([], [], []);) 2025.06.13 15:52:17.656278 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Array(Nothing): In scope SELECT tupleElement([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:17.791693 [ 5110 ] {7aefa412-c42e-4a73-b905-21cb9d0b9ef8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1534, line 1538) (in query: SELECT tupleHammingDistance([], [], []);) 2025.06.13 15:52:17.856106 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:18.230479 [ 5110 ] {b45f1fdc-955a-48ba-b530-a1b26029f877} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1535, line 1539) (in query: SELECT tupleIntDiv([], [], []);) 2025.06.13 15:52:18.281440 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:18.481388 [ 5110 ] {dc1b1e8f-9190-4d35-b2ed-cd083e65c9f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1536, line 1540) (in query: SELECT tupleIntDivByNumber([], [], []);) 2025.06.13 15:52:18.571715 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:18.704484 [ 5110 ] {91bb8d21-2cd3-452f-9d35-a42239fa05a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1537, line 1541) (in query: SELECT tupleIntDivOrZero([], [], []);) 2025.06.13 15:52:18.714187 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:18.983528 [ 5110 ] {5d9edec8-cd24-4f4b-9101-dd20c1b0e82b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1538, line 1542) (in query: SELECT tupleIntDivOrZeroByNumber([], [], []);) 2025.06.13 15:52:18.996234 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:19.063448 [ 5110 ] {ed8b360b-397a-4e8f-ba78-18f06ef039dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1539, line 1543) (in query: SELECT tupleMinus([], [], []);) 2025.06.13 15:52:19.068557 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:19.237563 [ 5110 ] {3d4c28b6-0722-472a-b3c3-fe847b5883db} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1540, line 1544) (in query: SELECT tupleModulo([], [], []);) 2025.06.13 15:52:19.257050 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:19.334434 [ 5110 ] {317f3f9c-e57a-42cc-bae3-e59d0f3ff9a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1541, line 1545) (in query: SELECT tupleModuloByNumber([], [], []);) 2025.06.13 15:52:19.345416 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:19.448903 [ 5110 ] {595e9c2f-cff5-4295-b176-1c8e622b4d88} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1542, line 1546) (in query: SELECT tupleMultiply([], [], []);) 2025.06.13 15:52:19.479774 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:19.750384 [ 5110 ] {0859e5bc-ee2e-4efc-90c9-d93b9880d8d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1543, line 1547) (in query: SELECT tupleMultiplyByNumber([], [], []);) 2025.06.13 15:52:19.760688 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:20.026772 [ 5110 ] {fbe9d366-d62b-4eb5-bcfc-f78fbd09d789} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1544, line 1548) (in query: SELECT tupleNames([], [], []);) 2025.06.13 15:52:20.106765 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:20.422779 [ 5110 ] {ddb98d2a-4858-492b-9c3f-d18e06aff617} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1545, line 1549) (in query: SELECT tupleNegate([], [], []);) 2025.06.13 15:52:20.498989 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:20.695641 [ 5110 ] {3b47dec8-26e2-486f-8378-d2102841b04a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1546, line 1550) (in query: SELECT tuplePlus([], [], []);) 2025.06.13 15:52:20.730052 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:20.981808 [ 5110 ] {424145f7-905e-4455-b2c9-a7805b8bc6af} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1547, line 1551) (in query: SELECT tupleToNameValuePairs([], [], []);) 2025.06.13 15:52:21.049498 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:21.277541 [ 5110 ] {75faa317-b0bf-459a-bd35-4fb276b2c652} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1548, line 1552) (in query: SELECT ucase([], [], []);) 2025.06.13 15:52:21.298081 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:21.385833 [ 5110 ] {3a60d651-70e9-40ce-a9b1-a8f5e2280be4} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1549, line 1553) (in query: SELECT unbin([], [], []);) 2025.06.13 15:52:21.391086 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:21.564232 [ 5110 ] {a8cbe240-0379-40d5-b374-ab7084def3ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1550, line 1554) (in query: SELECT unhex([], [], []);) 2025.06.13 15:52:21.598068 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:23.632679 [ 5110 ] {2ca53947-f887-4b31-9f42-8ba1b96d4657} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1557, line 1561) (in query: SELECT uniqThetaIntersect([], [], []);) 2025.06.13 15:52:23.648056 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:23.740652 [ 5110 ] {133871c5-7d76-47af-83ed-b6818ac8709b} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1558, line 1562) (in query: SELECT uniqThetaNot([], [], []);) 2025.06.13 15:52:23.776489 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:24.033966 [ 5110 ] {78251405-afee-4f09-bfff-aa5f0ffc1309} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1559, line 1563) (in query: SELECT uniqThetaUnion([], [], []);) 2025.06.13 15:52:24.038165 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:24.435767 [ 5110 ] {fecc18e3-aff6-433d-9d19-5500e1b27a92} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1561, line 1565) (in query: SELECT upper([], [], []);) 2025.06.13 15:52:24.454409 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:24.804167 [ 5110 ] {a7f0dbaa-3807-42e9-9cbb-00d7cf6e4666} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1562, line 1566) (in query: SELECT upperUTF8([], [], []);) 2025.06.13 15:52:24.838240 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:25.159521 [ 5110 ] {a60cd232-e896-4e55-92b3-be923972162d} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1563, line 1567) (in query: SELECT uptime([], [], []);) 2025.06.13 15:52:25.162673 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:25.288146 [ 5110 ] {dfc4359e-6330-4136-8ee5-02b568b99167} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1564, line 1568) (in query: SELECT user([], [], []);) 2025.06.13 15:52:25.364265 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:25.703814 [ 5110 ] {bde15b0c-bc9b-4abc-97b4-5a374ee3568e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function validateNestedArraySizes Must be UInt.: In scope SELECT validateNestedArraySizes([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1565, line 1569) (in query: SELECT validateNestedArraySizes([], [], []);) 2025.06.13 15:52:25.708322 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function validateNestedArraySizes Must be UInt.: In scope SELECT validateNestedArraySizes([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:25.845822 [ 5110 ] {2554ef53-dbd6-4af2-b2fd-c258227c0797} executeQuery: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1566, line 1570) (in query: SELECT varPop([], [], []);) 2025.06.13 15:52:25.898967 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:26.064211 [ 5110 ] {81d9a939-d5ed-431c-8364-43d5043b75e9} executeQuery: Code: 42. DB::Exception: Aggregate function varPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1567, line 1571) (in query: SELECT varPopStable([], [], []);) 2025.06.13 15:52:26.078686 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:26.383724 [ 5110 ] {6ab58cf7-236b-4d90-9186-a0bdf3590090} executeQuery: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1568, line 1572) (in query: SELECT varSamp([], [], []);) 2025.06.13 15:52:26.388860 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:26.517477 [ 5110 ] {9f31c026-428b-4a32-9c5b-6faff5c0c320} executeQuery: Code: 42. DB::Exception: Aggregate function varSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1569, line 1573) (in query: SELECT varSampStable([], [], []);) 2025.06.13 15:52:26.531992 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:26.704608 [ 5110 ] {3cd4a34c-6ebc-4def-b42c-daae776f65f9} executeQuery: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Array(Nothing): In scope SELECT variantElement([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1570, line 1574) (in query: SELECT variantElement([], [], []);) 2025.06.13 15:52:26.747527 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Array(Nothing): In scope SELECT variantElement([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:26.903114 [ 5110 ] {2ee949fb-cc23-4ee0-89f5-2e06e9bc6af0} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1571, line 1575) (in query: SELECT variantType([], [], []);) 2025.06.13 15:52:26.927541 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:27.129322 [ 5110 ] {7d30c708-380e-4b48-93a1-40d6b8ba99c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1572, line 1576) (in query: SELECT vectorDifference([], [], []);) 2025.06.13 15:52:27.199189 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:27.665401 [ 5110 ] {82070672-f69c-4fd9-8a6c-d43b918dc620} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1573, line 1577) (in query: SELECT vectorSum([], [], []);) 2025.06.13 15:52:27.748351 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:27.915580 [ 7755 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:28.021039 [ 5110 ] {c8e56eb8-7350-4ceb-b756-8f35f9077da8} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1574, line 1578) (in query: SELECT version([], [], []);) 2025.06.13 15:52:28.082932 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:28.206324 [ 5110 ] {5f636a02-3021-40c7-9d23-33c867cd8a30} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1575, line 1579) (in query: SELECT visibleWidth([], [], []);) 2025.06.13 15:52:28.220656 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:28.280885 [ 5110 ] {3f693f1d-7f80-450d-936d-ce5b9354c609} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1576, line 1580) (in query: SELECT visitParamExtractBool([], [], []);) 2025.06.13 15:52:28.297929 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:28.447862 [ 5110 ] {b5a40830-b05c-45eb-91a0-1bdb6c1811b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1577, line 1581) (in query: SELECT visitParamExtractFloat([], [], []);) 2025.06.13 15:52:28.473507 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:28.543276 [ 5110 ] {0bb8f982-02dd-4e55-8307-36cb3efbae5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1578, line 1582) (in query: SELECT visitParamExtractInt([], [], []);) 2025.06.13 15:52:28.550547 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:28.585778 [ 5110 ] {e1b18eb8-68d5-4113-ae56-5c81e787c661} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1579, line 1583) (in query: SELECT visitParamExtractRaw([], [], []);) 2025.06.13 15:52:28.591668 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:28.635486 [ 5110 ] {c0e76f97-6e8e-461b-b944-c326bb54ed94} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1580, line 1584) (in query: SELECT visitParamExtractString([], [], []);) 2025.06.13 15:52:28.642611 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:28.721539 [ 5110 ] {2ef5da16-4281-4adc-b256-0045dddedf7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1581, line 1585) (in query: SELECT visitParamExtractUInt([], [], []);) 2025.06.13 15:52:28.728274 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:28.865047 [ 5110 ] {54780155-f735-4292-adf3-241bb7420278} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1582, line 1586) (in query: SELECT visitParamHas([], [], []);) 2025.06.13 15:52:28.875077 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:28.912960 [ 5110 ] {339d4c93-a411-486d-808b-c4a5c9df771a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT week([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1583, line 1587) (in query: SELECT week([], [], []);) 2025.06.13 15:52:28.919352 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT week([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:28.949821 [ 5110 ] {26bf6c58-fcc7-42e5-9dc8-cb4d48c37083} executeQuery: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1584, line 1588) (in query: SELECT welchTTest([], [], []);) 2025.06.13 15:52:28.959861 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:28.995197 [ 5110 ] {b79ba952-0845-4ace-beaf-e8236731d7fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1585, line 1589) (in query: SELECT widthBucket([], [], []);) 2025.06.13 15:52:28.996370 [ 6234 ] {594cbe04-e6ff-4e49-a09c-8ec618c5c39c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:47418) (comment: 00094_union_race_conditions_5.sh) (query 54, line 54) (in query: SELECT * FROM system.numbers_mt LIMIT 111;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:29.001067 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:29.020938 [ 6234 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:29.103107 [ 5110 ] {25009b1c-9cf8-496a-a0dd-654ecf26fbef} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1586, line 1590) (in query: SELECT width_bucket([], [], []);) 2025.06.13 15:52:29.111552 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:29.250766 [ 5110 ] {e550c027-2c21-41ea-a215-11e58c3e6273} executeQuery: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1587, line 1591) (in query: SELECT windowFunnel([], [], []);) 2025.06.13 15:52:29.311415 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:29.382520 [ 5110 ] {fe47c387-cf1c-4830-a1ae-f86d36c9e9bf} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function windowID. Should be a date with time: In scope SELECT windowID([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1588, line 1592) (in query: SELECT windowID([], [], []);) 2025.06.13 15:52:29.394845 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function windowID. Should be a date with time: In scope SELECT windowID([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:29.473322 [ 5110 ] {c6483a24-587e-4223-8a65-accbfaa0425f} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1589, line 1593) (in query: SELECT wkt([], [], []);) 2025.06.13 15:52:29.481789 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:29.564912 [ 5110 ] {e3ffc330-ccd7-4626-a8cd-54998920482a} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHash must be String, got Array(Nothing): In scope SELECT wordShingleMinHash([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1590, line 1594) (in query: SELECT wordShingleMinHash([], [], []);) 2025.06.13 15:52:29.578093 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHash must be String, got Array(Nothing): In scope SELECT wordShingleMinHash([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:29.632150 [ 5110 ] {91fe55fc-dd56-4bd5-bed5-edc3d0038701} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArg must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArg([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1591, line 1595) (in query: SELECT wordShingleMinHashArg([], [], []);) 2025.06.13 15:52:29.714656 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArg must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArg([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:29.824842 [ 5110 ] {ad3ff04b-ea0e-4dda-ad2b-810f2cf11951} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1592, line 1596) (in query: SELECT wordShingleMinHashArgCaseInsensitive([], [], []);) 2025.06.13 15:52:29.829193 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:29.859665 [ 5110 ] {50e5859a-8d8e-4040-8cff-f633ddf51c4e} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1593, line 1597) (in query: SELECT wordShingleMinHashArgCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:52:29.864643 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:29.907364 [ 5110 ] {26d6ac3e-857f-4218-a9f9-056135f99482} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1594, line 1598) (in query: SELECT wordShingleMinHashArgUTF8([], [], []);) 2025.06.13 15:52:29.928188 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:29.983652 [ 5110 ] {aad24845-2d11-4fd7-be8e-ac86b6e87924} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleMinHashCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1595, line 1599) (in query: SELECT wordShingleMinHashCaseInsensitive([], [], []);) 2025.06.13 15:52:29.992275 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleMinHashCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:30.053114 [ 5110 ] {1936aed9-a0ad-4f8b-9256-47bc484a4900} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1596, line 1600) (in query: SELECT wordShingleMinHashCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:52:30.061709 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:30.105287 [ 5110 ] {a0918502-4a3a-4fc6-89ba-ffdba6fe91b4} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1597, line 1601) (in query: SELECT wordShingleMinHashUTF8([], [], []);) 2025.06.13 15:52:30.111222 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:30.160562 [ 5110 ] {c1f42912-703f-45f8-b574-9e18692afa74} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHash must be String, got Array(Nothing): In scope SELECT wordShingleSimHash([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1598, line 1602) (in query: SELECT wordShingleSimHash([], [], []);) 2025.06.13 15:52:30.165750 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHash must be String, got Array(Nothing): In scope SELECT wordShingleSimHash([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:30.205210 [ 5110 ] {7380f5ae-8fbc-4db2-8391-9e7f2d77ea48} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleSimHashCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1599, line 1603) (in query: SELECT wordShingleSimHashCaseInsensitive([], [], []);) 2025.06.13 15:52:30.217576 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleSimHashCaseInsensitive([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:30.276375 [ 5110 ] {7d31d7cf-136b-40ad-b92e-775f3d27c4a2} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleSimHashCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1600, line 1604) (in query: SELECT wordShingleSimHashCaseInsensitiveUTF8([], [], []);) 2025.06.13 15:52:30.282733 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleSimHashCaseInsensitiveUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:30.327045 [ 5110 ] {115382c0-884f-40aa-ac6f-57fd1051f503} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleSimHashUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1601, line 1605) (in query: SELECT wordShingleSimHashUTF8([], [], []);) 2025.06.13 15:52:30.331953 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleSimHashUTF8([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:30.513354 [ 5110 ] {2e482475-1882-4fb9-9f5d-8030e3e1d5fd} executeQuery: Code: 43. DB::Exception: Illegal type (Array(Nothing)) of 1 argument of function xor: In scope SELECT xor([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1603, line 1607) (in query: SELECT xor([], [], []);) 2025.06.13 15:52:30.618591 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(Nothing)) of 1 argument of function xor: In scope SELECT xor([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:31.170852 [ 5110 ] {b409435a-c534-4002-9798-ddc0baa58e79} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1607, line 1611) (in query: SELECT yandexConsistentHash([], [], []);) 2025.06.13 15:52:31.177473 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:31.317001 [ 5110 ] {f2dbffed-c1d5-4f95-bd2a-5cc5bfc6de3f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT yearweek([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1608, line 1612) (in query: SELECT yearweek([], [], []);) 2025.06.13 15:52:31.332923 [ 5110 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT yearweek([], [], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:52:31.423268 [ 5110 ] {4c60ef12-2d85-4599-b8c8-9bcc1dacdf8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1609, line 1613) (in query: SELECT yesterday([], [], []);) 2025.06.13 15:52:31.428547 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:31.519734 [ 5110 ] {14165417-e410-4702-8eb6-0555d8707cdf} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35000) (comment: 00534_functions_bad_arguments12.sh) (query 1610, line 1614) (in query: SELECT zookeeperSessionUptime([], [], []);) 2025.06.13 15:52:31.525970 [ 5110 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime([], [], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:52:32.440021 [ 11340 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Session expired (fault injected on recv). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x0000000031173f2d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x0000000031173e22 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1787: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000003281a020 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:927: Coordination::ZooKeeper::receiveEvent() @ 0x0000000032817d52 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:874: Coordination::ZooKeeper::receiveThread() @ 0x0000000032816c4f 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:452: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000032823e9e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:32.452875 [ 3308 ] {} test_3.replicated_truncate2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:52:32.458285 [ 3369 ] {} test_3.replicated_numbers (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:52:32.471255 [ 3287 ] {} test_13.enum_alter_issue (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:52:32.471392 [ 3256 ] {} test_13.replicated_mutations_empty_partitions (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:52:32.475411 [ 3333 ] {} test_13.sample_table_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:52:32.480528 [ 2895 ] {} test_3.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:52:32.484296 [ 3355 ] {} test_1.wrong_metadata (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:52:32.485847 [ 3296 ] {} test_1.wrong_metadata_compact (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:52:32.487877 [ 3317 ] {} test_13.`02784_async_table_with_dedup` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:52:32.525026 [ 2871 ] {} test_3.mt_compact (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:52:32.529143 [ 3339 ] {} test_13.tp_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:52:32.568040 [ 3316 ] {} test_zmookgdx.table_for_rename1 (1f35adba-c40f-4270-8870-35eb4ecb9a99): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:32.578596 [ 3326 ] {} test_rov98m53.r_prop_table2 (72e89099-3a93-46b1-908c-5e28dba47b51): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:32.579234 [ 2873 ] {} test_rov98m53.r_prop_table1 (c9b29f0c-79dc-4e58-995e-cd151897d715): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:32.584367 [ 34704 ] {} DatabaseCatalog: Cannot drop table test_jn1gj4rw_02911_keeper_map.`02911_backup_restore_keeper_map3` (ecd74de4-467f-4a9c-bac0-34b813db2b0c). Will retry later.: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test_keeper_map/test_jn1gj4rw/test02911_different/data/VAMAAAAAAAA=. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001af98c7c 5. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001af984d0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755b6f 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:347: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003275556c 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:322: zkutil::ZooKeeper::removeChildrenRecursive(String const&, zkutil::RemoveException) @ 0x000000003275d892 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:882: zkutil::ZooKeeper::removeChildrenRecursive(String const&, zkutil::RemoveException) @ 0x000000003275dd9d 10. ./build_docker/./src/Storages/StorageKeeperMap.cpp:716: DB::StorageKeeperMap::dropTable(std::shared_ptr, std::shared_ptr const&) @ 0x0000000030495010 11. ./build_docker/./src/Storages/StorageKeeperMap.cpp:804: DB::StorageKeeperMap::drop() @ 0x000000003049751a 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d5f99b1 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d607d44 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 15. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:32.716595 [ 9636 ] {f223c265-1031-4d74-b297-37683bcc05f5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38768) (comment: 03355_issue_32743.sql) (in query: DROP DATABASE IF EXISTS test_vcrt89fw SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:52:32.718878 [ 9636 ] {f223c265-1031-4d74-b297-37683bcc05f5} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:32.914856 [ 3982 ] {c1f903a3-34d9-4c38-a984-b67ea4cb2f4d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40618) (comment: 03355_issue_32743.sql) (in query: DROP DATABASE IF EXISTS test_vcrt89fw SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:52:32.920765 [ 3982 ] {c1f903a3-34d9-4c38-a984-b67ea4cb2f4d} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:34.142235 [ 3982 ] {f4961c34-a913-44cb-9e35-2f8e3afc42bb} executeQuery: Code: 36. DB::Exception: The coordinates of the point are such that subsequent calculations cannot be performed correctly. Most likely they are very large in modulus.: In scope SELECT pointInPolygon((0, 0), [[(0, 0), (10, 10), (256, -9223372036854775808)]]). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33886) (comment: 01700_point_in_polygon_ubsan.sql) (query 1, line 1) (in query: SELECT pointInPolygon((0, 0), [[(0, 0), (10, 10), (256, -9223372036854775808)]]) FORMAT Null ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::(anonymous namespace)::FunctionPointInPolygon>::parseRing, false, true, std::vector, std::allocator>>(double const*, double const*, unsigned long, unsigned long, boost::geometry::model::ring, false, true, std::vector, std::allocator>&) const @ 0x000000001ff548ba 6. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff4f9ac 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:52:34.157432 [ 3982 ] {} TCPHandler: Code: 36. DB::Exception: The coordinates of the point are such that subsequent calculations cannot be performed correctly. Most likely they are very large in modulus.: In scope SELECT pointInPolygon((0, 0), [[(0, 0), (10, 10), (256, -9223372036854775808)]]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. void DB::(anonymous namespace)::FunctionPointInPolygon>::parseRing, false, true, std::vector, std::allocator>>(double const*, double const*, unsigned long, unsigned long, boost::geometry::model::ring, false, true, std::vector, std::allocator>&) const @ 0x000000001ff548ba 6. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ff4f9ac 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:52:35.326530 [ 34313 ] {0b15a8e0-f3a3-4709-bd61-111838ab3b5c} executeQuery: Code: 691. DB::Exception: Unexpected value 2 in enum: while executing 'FUNCTION toString(__table1.v :: 0) -> toString(__table1.v) String : 1'. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35090) (comment: 01263_type_conversion_nvartolomei.sql) (query 15, line 46) (in query: SELECT toString(v) FROM (SELECT v FROM d ORDER BY v) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000019f2c67c 6. ./src/DataTypes/EnumValues.h:54: void DB::detail::FormatImpl>::execute(DB::DataTypeEnum<_BitInt(8)>, DB::WriteBuffer&, DB::detail::FormatImpl> const*, DateLUTImpl const*) @ 0x000000002b220623 7. ./src/Functions/FunctionsConversion.h:1552: COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b21ff4d 8. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b20ad86 9. ./src/Core/callOnTypeIndex.h:283: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b065808 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b064663 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:52:35.343228 [ 34313 ] {} TCPHandler: Code: 691. DB::Exception: Unexpected value 2 in enum: while executing 'FUNCTION toString(__table1.v :: 0) -> toString(__table1.v) String : 1'. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x0000000019f2c67c 6. ./src/DataTypes/EnumValues.h:54: void DB::detail::FormatImpl>::execute(DB::DataTypeEnum<_BitInt(8)>, DB::WriteBuffer&, DB::detail::FormatImpl> const*, DateLUTImpl const*) @ 0x000000002b220623 7. ./src/Functions/FunctionsConversion.h:1552: COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b21ff4d 8. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b20ad86 9. ./src/Core/callOnTypeIndex.h:283: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b065808 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b064663 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:35.523843 [ 3982 ] {04704663-5b6c-4871-878e-367ebe2823dd} executeQuery: Code: 36. DB::Exception: It's not allowed to explicitly specify UUIDs for tables in Replicated databases, see database_replicated_allow_explicit_uuid. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33916) (comment: 02858_explicit_uuid_and_zk_path.sh) (query 1, line 1) (in query: CREATE TABLE test_5.m0 UUID '02858000-1000-4000-8000-000000000000' (n int) ENGINE=Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1406: DB::InterpreterCreateQuery::assertOrSetUUID(DB::ASTCreateQuery&, std::shared_ptr const&) const @ 0x000000002dc6e611 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1721: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71ff0 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:35.546098 [ 3982 ] {} TCPHandler: Code: 36. DB::Exception: It's not allowed to explicitly specify UUIDs for tables in Replicated databases, see database_replicated_allow_explicit_uuid. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1406: DB::InterpreterCreateQuery::assertOrSetUUID(DB::ASTCreateQuery&, std::shared_ptr const&) const @ 0x000000002dc6e611 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1721: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71ff0 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:36.026368 [ 3982 ] {2e815c42-e7c0-4ecf-9030-a6baa60ce0cb} InterpreterCreateQuery: It's not recommended to explicitly specify UUIDs for tables in Replicated databases 2025.06.13 15:52:36.142698 [ 3982 ] {2e815c42-e7c0-4ecf-9030-a6baa60ce0cb} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33928) (comment: 02858_explicit_uuid_and_zk_path.sh) (query 1, line 1) (in query: CREATE TABLE test_5.m1 UUID '02858000-1000-4000-8000-000000000357' (n int) ENGINE=Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:36.157866 [ 3982 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:36.581256 [ 18510 ] {255f1dd1-f2bd-421a-8bd0-b132b8017270} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 20, line 7) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:36.613506 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:36.644277 [ 44700 ] {3392d369-5047-431c-875d-2a95dd22fcad} InterpreterCreateQuery: Replaced a user-provided UUID (02858000-1000-4000-8000-000000000002) with a random one (23c4dc42-e419-4d13-b53e-0e5a2827d333) to make sure it's unique 2025.06.13 15:52:36.789518 [ 44700 ] {3392d369-5047-431c-875d-2a95dd22fcad} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33932) (comment: 02858_explicit_uuid_and_zk_path.sh) (query 1, line 1) (in query: CREATE TABLE test_5.m2 UUID '02858000-1000-4000-8000-000000000002' (n int) ENGINE=Memory), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:36.801261 [ 44700 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:37.430107 [ 46451 ] {03d213a8-eb2b-4c21-b9f6-5ab33f3a8b76} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33960) (comment: 02858_explicit_uuid_and_zk_path.sh) (query 1, line 1) (in query: CREATE TABLE test_5.rmt0 (n int) ENGINE=ReplicatedMergeTree('/test/02858_explicit_uuid_and_zk_path_test_5/rmt/{shard}', '_{replica}') ORDER BY n), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:37.445801 [ 46451 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:37.577125 [ 6219 ] {545090a8-cdbf-4080-aa34-f3d102ab2db7} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_jn1gj4rw_02911_keeper_map.02911_backup_restore_keeper_map3' in scope SELECT count() FROM test_jn1gj4rw_02911_keeper_map.`02911_backup_restore_keeper_map3`. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33982) (comment: 02911_backup_restore_keeper_map.sh) (query 1, line 1) (in query: SELECT count() FROM test_jn1gj4rw_02911_keeper_map.02911_backup_restore_keeper_map3;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:52:37.605238 [ 6219 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_jn1gj4rw_02911_keeper_map.02911_backup_restore_keeper_map3' in scope SELECT count() FROM test_jn1gj4rw_02911_keeper_map.`02911_backup_restore_keeper_map3`. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:52:37.861055 [ 42481 ] {} ExternalDictionariesLoader: Could not update external dictionary '0be08daa-5789-4ac9-9d3b-e3d52a3ffe86', leaving the previous version, next update is scheduled at 2025-06-13 15:52:43: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=27, jobs=0): while reading column last_insert_time at /var/lib/clickhouse/store/6dd/6dda5caf-9dd7-423a-b600-93a10ec351c2/: While executing Log. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. ./build_docker/./src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x0000000023e63227 14. DB::ReadBuffer::next() @ 0x0000000017e74832 15. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9e815 16. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000032d9e14c 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c5f5ea3 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 19. ./build_docker/./src/Storages/StorageLog.cpp:269: DB::LogSource::readData(DB::NameAndTypePair const&, COW::immutable_ptr&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x000000003084f6e1 20. ./build_docker/./src/Storages/StorageLog.cpp:202: DB::LogSource::generate() @ 0x000000003084e340 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 28. void DB::mergeBlockWithPipe<(DB::DictionaryKeyType)0>(unsigned long, DB::Block&, DB::QueryPipeline) @ 0x0000000028a8998a 29. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, false>::updateData() @ 0x000000002912553c 30. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, false>::loadData() @ 0x000000002911e517 31. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, false>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x000000002911da7e (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:38.087770 [ 46451 ] {8e431b37-3009-49c0-b3dc-c2ebee32fed6} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:33992) (comment: 02858_explicit_uuid_and_zk_path.sh) (query 1, line 1) (in query: CREATE TABLE test_5.rmt1 (n int) ENGINE=ReplicatedMergeTree('/test/02858_explicit_uuid_and_zk_path_test_5/rmt/{shard}', '_{replica}') ORDER BY n), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:38.100070 [ 46451 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:38.833581 [ 46451 ] {cdda9fc8-fd6b-4205-8be3-48323ea8d81b} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34026) (comment: 02858_explicit_uuid_and_zk_path.sh) (query 1, line 1) (in query: CREATE TABLE test_5.rmt2 (n int) ENGINE=ReplicatedMergeTree('/test/02858_explicit_uuid_and_zk_path_test_5/rmt/{shard}', '_{replica}') ORDER BY n), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:38.851135 [ 46451 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:39.594418 [ 5112 ] {44b8d5b7-c164-4f08-81fa-dc7142e9f4bc} executeQuery: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60386) (comment: 00753_alter_attach.sql) (query 42, line 67) (in query: ALTER TABLE replicated_table_detach_all1 FETCH PARTITION ALL FROM '/clickhouse/tables/test_00753_{database}/replicated_table_detach_all1';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5401: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000030cfbd11 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4185f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:39.607052 [ 5112 ] {} TCPHandler: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5401: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000030cfbd11 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4185f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:40.993155 [ 3499 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:41.030718 [ 3503 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:41.079141 [ 44700 ] {23ad09b3-e97f-4363-beb8-5cde85eb4d60} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20000101_1_1_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 . (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 00834_kill_mutation.sh) (in query: /* ddl_entry=query-0000000003 */ ALTER TABLE test_kb3dcbk9.kill_mutation (DELETE WHERE toUInt32(s) = 1) SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:52:41.122621 [ 45124 ] {934459e1-d179-4a41-95e3-87c4358c1d4e} executeQuery: Code: 390. DB::Exception: Table `rmt1` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34130) (comment: 02858_explicit_uuid_and_zk_path.sh) (query 1, line 1) (in query: SHOW CREATE test_5.rmt1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002c725068 6. ./src/Databases/IDatabase.h:350: DB::IDatabase::getCreateTableQuery(String const&, std::shared_ptr) const @ 0x000000002c029e21 7. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:66: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000002e32b399 8. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x000000002e32abcc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:52:41.138713 [ 3499 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:41.139218 [ 3503 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:41.141024 [ 3499 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:41.141724 [ 3503 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_3}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:41.150965 [ 45124 ] {} TCPHandler: Code: 390. DB::Exception: Table `rmt1` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002c725068 6. ./src/Databases/IDatabase.h:350: DB::IDatabase::getCreateTableQuery(String const&, std::shared_ptr) const @ 0x000000002c029e21 7. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:66: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000002e32b399 8. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x000000002e32abcc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:52:41.158583 [ 44700 ] {23ad09b3-e97f-4363-beb8-5cde85eb4d60} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20000101_1_1_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 . (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34098) (comment: 00834_kill_mutation.sh) (query 1, line 1) (in query: ALTER TABLE kill_mutation DELETE WHERE toUInt32(s) = 1 SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:52:41.182598 [ 44700 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20000101_1_1_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:52:41.227158 [ 18510 ] {7c912b93-8819-42c3-b186-a535f92ccfdc} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 38, line 13) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:41.251591 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:41.559440 [ 44700 ] {55e507ed-3d62-4891-93da-55fa3ba9e5f0} executeQuery: Code: 390. DB::Exception: Table `rmt2` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34136) (comment: 02858_explicit_uuid_and_zk_path.sh) (query 1, line 1) (in query: SHOW CREATE test_5.rmt2), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002c725068 6. ./src/Databases/IDatabase.h:350: DB::IDatabase::getCreateTableQuery(String const&, std::shared_ptr) const @ 0x000000002c029e21 7. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:66: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000002e32b399 8. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x000000002e32abcc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:52:41.595976 [ 44700 ] {} TCPHandler: Code: 390. DB::Exception: Table `rmt2` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:549: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x000000002c725068 6. ./src/Databases/IDatabase.h:350: DB::IDatabase::getCreateTableQuery(String const&, std::shared_ptr) const @ 0x000000002c029e21 7. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:66: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000002e32b399 8. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:34: DB::InterpreterShowCreateQuery::execute() @ 0x000000002e32abcc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:52:42.380163 [ 3499 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:42.390427 [ 3499 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:42.483916 [ 3499 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:42.490945 [ 3512 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:42.495567 [ 3512 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:42.590386 [ 3512 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_3}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:43.028628 [ 45511 ] {6b1d07c3-51ea-4a36-9050-729642be505e} executeQuery: Code: 12. DB::Exception: Exceeded limit for `max_streams` with `max_streams_to_max_threads_ratio`. Make sure that `max_streams * max_streams_to_max_threads_ratio` is in some reasonable boundaries, current value: -9.453956e+21. (PARAMETER_OUT_OF_BOUND) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34172) (comment: 03148_setting_max_streams_to_max_threads_ratio_overflow.sql) (query 4, line 10) (in query: SELECT * FROM test_table SETTINGS max_threads = 1025, max_streams_to_max_threads_ratio = -9223372036854775808, enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, float&) @ 0x0000000020ad932f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:781: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dd9d563 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 7. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:43.044799 [ 45511 ] {} TCPHandler: Code: 12. DB::Exception: Exceeded limit for `max_streams` with `max_streams_to_max_threads_ratio`. Make sure that `max_streams * max_streams_to_max_threads_ratio` is in some reasonable boundaries, current value: -9.453956e+21. (PARAMETER_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, float&) @ 0x0000000020ad932f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:781: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002dd9d563 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2251: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002dd9499b 7. ./build_docker/./src/Planner/Planner.cpp:1568: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6d57a 8. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:43.063956 [ 45511 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:43.069429 [ 45511 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:52:43.112172 [ 5112 ] {c899f95c-69bc-42b5-8e03-4fb0db86c9a1} executeQuery: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60386) (comment: 00753_alter_attach.sql) (query 51, line 81) (in query: -- test PARTITION ALL ALTER TABLE partition_all2 REPLACE PARTITION ALL FROM partition_all;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5401: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000030cfbd11 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4185f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:43.215848 [ 5112 ] {} TCPHandler: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5401: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000030cfbd11 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4185f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:43.324798 [ 5112 ] {689cb2a5-d546-46c5-86f3-dbe1f94cfb25} executeQuery: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60386) (comment: 00753_alter_attach.sql) (query 52, line 83) (in query: ALTER TABLE partition_all MOVE PARTITION ALL TO TABLE partition_all2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5401: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000030cfbd11 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4185f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:43.339112 [ 5112 ] {} TCPHandler: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5401: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000030cfbd11 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4185f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:43.464917 [ 5112 ] {f5912e01-9fd0-41f6-aebb-c672488c9b91} executeQuery: Code: 344. DB::Exception: Only Support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60386) (comment: 00753_alter_attach.sql) (query 53, line 84) (in query: ALTER TABLE partition_all2 CLEAR INDEX p IN PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6257: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cced20 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3642: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc7d85 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:52:43.498942 [ 5112 ] {} TCPHandler: Code: 344. DB::Exception: Only Support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6257: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cced20 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3642: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc7d85 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:52:43.586524 [ 5112 ] {dad4cfe4-b6b8-42c2-a78f-df48ff1393d2} executeQuery: Code: 344. DB::Exception: Only Support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60386) (comment: 00753_alter_attach.sql) (query 54, line 85) (in query: ALTER TABLE partition_all2 CLEAR COLUMN q IN PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6257: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cced20 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3642: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc7d85 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:52:43.604413 [ 5112 ] {} TCPHandler: Code: 344. DB::Exception: Only Support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6257: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cced20 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3642: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000030cc7d85 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc412ea 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:52:43.827757 [ 5112 ] {faef31a8-8f61-45f1-a20b-79a31361c035} executeQuery: Code: 344. DB::Exception: Only Support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60386) (comment: 00753_alter_attach.sql) (query 55, line 86) (in query: ALTER TABLE partition_all2 UPDATE q = q + 1 IN PARTITION ALL where p = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6257: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cced20 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:257: DB::getPartitionAndPredicateExpressionForMutationCommand(DB::MutationCommand const&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002de9bd68 7. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1538: DB::MutationsInterpreter::prepare(bool) @ 0x000000002dea2fb1 8. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:405: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x000000002de9e05d 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc416d5 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:52:43.853096 [ 5112 ] {} TCPHandler: Code: 344. DB::Exception: Only Support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6257: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cced20 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:257: DB::getPartitionAndPredicateExpressionForMutationCommand(DB::MutationCommand const&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002de9bd68 7. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1538: DB::MutationsInterpreter::prepare(bool) @ 0x000000002dea2fb1 8. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:405: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x000000002de9e05d 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc416d5 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:52:43.979463 [ 5112 ] {74b75fcd-bfb0-438c-9878-f55d0b840cc8} executeQuery: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60386) (comment: 00753_alter_attach.sql) (query 56, line 87) (in query: ALTER TABLE partition_all2 FREEZE PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5401: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000030cfbd11 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4185f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:44.005554 [ 5112 ] {} TCPHandler: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5401: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000030cfbd11 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc4185f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:44.210967 [ 5112 ] {39e1ac42-66a4-432b-869d-aa4f18a74e64} executeQuery: Code: 344. DB::Exception: Only Support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60386) (comment: 00753_alter_attach.sql) (query 57, line 88) (in query: CHECK TABLE partition_all2 PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6257: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cced20 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:2506: DB::StorageMergeTree::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x0000000031206f7d 7. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:110: DB::InterpreterCheckQuery::execute() @ 0x000000002e33bb5b 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:44.223412 [ 5112 ] {} TCPHandler: Code: 344. DB::Exception: Only Support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6257: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cced20 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:2506: DB::StorageMergeTree::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x0000000031206f7d 7. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:110: DB::InterpreterCheckQuery::execute() @ 0x000000002e33bb5b 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:44.463027 [ 5112 ] {27c06b15-c43e-4258-a8b1-96ea4b822f9d} executeQuery: Code: 344. DB::Exception: Only Support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60386) (comment: 00753_alter_attach.sql) (query 58, line 89) (in query: OPTIMIZE TABLE partition_all2 PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6257: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cced20 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1708: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e9588 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:44.479537 [ 5112 ] {} TCPHandler: Code: 344. DB::Exception: Only Support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6257: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000030cced20 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:1708: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000311e9588 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x000000002e325f37 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:44.575768 [ 5163 ] {e110c123-4f9f-40ce-9b0c-9a49f64cbd53} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36810) (comment: 01529_bad_memory_tracking.sh) (query 1, line 1) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:52:44.586342 [ 5163 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:44.831736 [ 3500 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_4} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:44.901213 [ 3501 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_4} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:44.902884 [ 3500 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:44.903715 [ 18510 ] {6b2e74eb-0601-40ab-a383-ae8a7066b3fb} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 53, line 18) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:44.905505 [ 3500 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_4}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:44.915705 [ 3501 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:44.918083 [ 3501 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_4}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:44.992179 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:45.079859 [ 45124 ] {ca66b6aa-8b2a-46fd-bc8e-958101fbc5eb} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36828) (comment: 01529_bad_memory_tracking.sh) (query 1, line 1) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:52:45.086187 [ 45124 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:45.124400 [ 3499 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_4} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.135339 [ 3499 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.143886 [ 3499 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_4}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.243281 [ 3502 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_4} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.252981 [ 3502 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.259576 [ 3502 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_4}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.298654 [ 3506 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_4} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.301784 [ 3506 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_4} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.305293 [ 3506 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.609247 [ 18510 ] {aab5cfd6-1cec-45b9-9ba3-819fa4804eb0} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 56, line 19) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:45.635286 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:45.642989 [ 3509 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_4} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.643817 [ 3503 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_4} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.646819 [ 3509 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.647614 [ 3503 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.649266 [ 3503 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_4}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.649372 [ 3509 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_4}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:45.660435 [ 5112 ] {1cdab037-bb3d-4ea6-ba94-1d8d5a62c8f2} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 4.21 MiB (attempt to allocate chunk of 1.05 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60386) (comment: 00753_alter_attach.sql) (query 62, line 96) (in query: INSERT INTO partition_attach_all VALUES ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b684b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b683f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b67671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023cffee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c94d347 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c93f7d8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030af5e0c 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000030de68cc 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030de6026 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd68e3 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dc188d 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c5a27a 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030feff3e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e43ccf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e3f751 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031229dad 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f67cf7 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 2025.06.13 15:52:45.687073 [ 5112 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 4.21 MiB (attempt to allocate chunk of 1.05 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b684b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b683f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b67671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023cffee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c94d347 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c93f7d8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030af5e0c 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000030de68cc 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030de6026 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd68e3 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dc188d 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c5a27a 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030feff3e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e43ccf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e3f751 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031229dad 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f67cf7 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 2025.06.13 15:52:45.720641 [ 45124 ] {4f52f44e-da9c-4abf-9b12-a85e9d5e9f42} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36858) (comment: 01529_bad_memory_tracking.sh) (query 1, line 1) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:52:45.751419 [ 45124 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:46.005503 [ 3505 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:46.010083 [ 3505 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:46.012099 [ 3505 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_5}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:46.013059 [ 44700 ] {cc76f595-4966-444d-97c7-2e968e26f87b} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutations 'mutation_4.txt, mutation_5.txt' with part '20000101_1_1_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 . (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 00834_kill_mutation.sh) (in query: /* ddl_entry=query-0000000005 */ ALTER TABLE test_kb3dcbk9.kill_mutation (DELETE WHERE x = 1) SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:52:46.047250 [ 3499 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:46.061686 [ 3499 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:46.078689 [ 3499 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_5}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:46.176110 [ 44700 ] {cc76f595-4966-444d-97c7-2e968e26f87b} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutations 'mutation_4.txt, mutation_5.txt' with part '20000101_1_1_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 . (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36842) (comment: 00834_kill_mutation.sh) (query 1, line 1) (in query: ALTER TABLE kill_mutation DELETE WHERE x = 1 SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:52:46.198293 [ 44700 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutations 'mutation_4.txt, mutation_5.txt' with part '20000101_1_1_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f014f4 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000030f016b7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000030f01556 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x00000000311d3105 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::waitForMutation(long, bool) @ 0x00000000311cea26 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:720: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000311d4fa5 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc3ffb0 18. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:52:46.214056 [ 3502 ] {491c9866-f7d9-4f23-b8a1-f8009bc022c4::202506_106_150_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1125: DB::MergeTask::VerticalMergeStage::createPipelineForReadingOneColumn(String const&) const @ 0x0000000030c1e97a 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1149: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000030c1faa2 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x0000000030c28ab4 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000030c27ad7 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:46.226167 [ 3502 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {491c9866-f7d9-4f23-b8a1-f8009bc022c4::202506_106_150_12}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1125: DB::MergeTask::VerticalMergeStage::createPipelineForReadingOneColumn(String const&) const @ 0x0000000030c1e97a 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1149: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000030c1faa2 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x0000000030c28ab4 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000030c27ad7 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:46.324017 [ 46648 ] {9aec1f39-9618-45e1-ad56-b7b776cf005f} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36870) (comment: 01529_bad_memory_tracking.sh) (query 1, line 1) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:52:46.339887 [ 46648 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:46.494632 [ 3508 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:46.499081 [ 3501 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:46.499160 [ 3508 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:46.500951 [ 3508 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_5}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:46.509524 [ 3501 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:46.520425 [ 3501 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_5}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:46.696214 [ 18510 ] {b1e8b257-85c3-414f-94fa-0cc8b17a3f81} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 62, line 21) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:46.716807 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:46.772072 [ 46014 ] {e90afdc8-d5ce-4517-bc2b-c5f694da3beb} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36892) (comment: 01529_bad_memory_tracking.sh) (query 1, line 1) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:52:46.781745 [ 46014 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:47.076377 [ 3508 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:47.089533 [ 3508 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:47.093694 [ 3508 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20000101_1_1_0_5}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:47.197844 [ 3501 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:47.200176 [ 3501 ] {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:47.201601 [ 3501 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6b8fce3a-4400-44e4-b328-2b7f6c72e94d::20010101_2_2_0_5}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000017e8084c 5. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002b098c20 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b091fc8 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02a88e 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b0359de 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b034843 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002de99faa 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x0000000031016ba9 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x00000000310158f9 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x00000000312338ff 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:52:47.308703 [ 46014 ] {3fc4d57c-2b4f-431c-bf4b-bdbfee49fa3a} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36900) (comment: 01529_bad_memory_tracking.sh) (query 1, line 1) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:52:47.317406 [ 46014 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:47.640632 [ 45683 ] {c16af28c-7fd4-4afd-9a0d-1f873a3b7b45} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e') AS v, toTypeName(v). (UNKNOWN_SETTING) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36792) (comment: 01418_custom_settings.sql) (query 23, line 26) (in query: SELECT getSetting('custom_e') as v, toTypeName(v);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c07d5e0 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c27a727 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c27a528 7. ./build_docker/./src/Core/Settings.cpp:6484: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c17e718 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc2078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc1eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:52:47.647653 [ 45683 ] {} TCPHandler: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e') AS v, toTypeName(v). (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c07d5e0 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c27a727 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c27a528 7. ./build_docker/./src/Core/Settings.cpp:6484: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c17e718 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc2078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc1eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:52:47.721702 [ 8101 ] {36f21271-35a2-4a1f-903c-459adce8c2cf} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36912) (comment: 01529_bad_memory_tracking.sh) (query 1, line 1) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:52:47.732177 [ 8101 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:48.059246 [ 45683 ] {491ce478-506b-4fdf-b576-845cdc1bfd7b} executeQuery: Code: 115. DB::Exception: Setting invalid_custom is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36792) (comment: 01418_custom_settings.sql) (query 27, line 31) (in query: SET invalid_custom = 8;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Access/AccessControl.cpp:134: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002bcc4a7c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:279: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9238 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:48.079191 [ 45683 ] {} TCPHandler: Code: 115. DB::Exception: Setting invalid_custom is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Access/AccessControl.cpp:134: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x000000002bcc4a7c 6. ./build_docker/./src/Access/SettingsConstraints.cpp:279: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9238 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:48.191364 [ 8101 ] {54371d6f-c14c-4914-9ac4-add0541be9c9} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36936) (comment: 01529_bad_memory_tracking.sh) (query 1, line 1) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:52:48.199151 [ 8101 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:48.217604 [ 45124 ] {dda04a81-0452-4a10-b744-d822ce9314aa} executeQuery: Code: 36. DB::Exception: Dictionary (`invalid_dictionary`) not found: In scope WITH 'invalid_dictionary' AS dictionary SELECT dictGet(dictionary, 'value', toUInt64(0)). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36876) (comment: 02384_analyzer_dict_get_join_get.sql) (query 12, line 33) (in query: WITH 'invalid_dictionary' AS dictionary SELECT dictGet(dictionary, 'value', toUInt64(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x000000002dbe2855 6. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x000000002dbe314f 7. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x0000000017f4c186 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017f4576a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:52:48.224658 [ 45124 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`invalid_dictionary`) not found: In scope WITH 'invalid_dictionary' AS dictionary SELECT dictGet(dictionary, 'value', toUInt64(0)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x000000002dbe2855 6. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:113: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x000000002dbe314f 7. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x0000000017f4c186 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017f4576a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:52:48.515481 [ 18510 ] {9b37bbe4-d9f8-4b74-90bf-d31045a23f0c} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 71, line 24) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:48.522390 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:48.660705 [ 46014 ] {445da76b-b238-45e5-96ae-ba4f1d9bccaa} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36960) (comment: 01529_bad_memory_tracking.sh) (query 1, line 1) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:52:48.691647 [ 46014 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:49.153213 [ 45683 ] {9bb957d0-d28b-44ab-907b-1b8cd63d3fdb} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_f': In scope SELECT getSetting('custom_f') AS v, toTypeName(v). (UNKNOWN_SETTING) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36792) (comment: 01418_custom_settings.sql) (query 35, line 41) (in query: SELECT getSetting('custom_f') as v, toTypeName(v);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c07d5e0 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c27a727 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c27a528 7. ./build_docker/./src/Core/Settings.cpp:6484: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c17e718 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc2078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc1eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:52:49.160079 [ 45683 ] {} TCPHandler: Code: 115. DB::Exception: Unknown setting 'custom_f': In scope SELECT getSetting('custom_f') AS v, toTypeName(v). (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x000000002c07d5e0 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::getCustomSetting(std::basic_string_view>) const @ 0x000000002c27a727 6. ./src/Core/BaseSettings.h:273: DB::BaseSettings::get(std::basic_string_view>) const @ 0x000000002c27a528 7. ./build_docker/./src/Core/Settings.cpp:6484: DB::Settings::get(std::basic_string_view>) const @ 0x000000002c17e718 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000001afc2078 9. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000001afc1eb2 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 27. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 28. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 2025.06.13 15:52:49.238074 [ 46014 ] {9c406cd7-be09-4d75-a7f7-416386beb5c4} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36974) (comment: 01529_bad_memory_tracking.sh) (query 1, line 1) (in query: SELECT i FROM generateRandom('i Array(Int8)', 1, 1, 1048577) LIMIT 65536), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:52:49.257352 [ 46014 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 64.00 GiB (attempt to allocate chunk of 64.00 GiB bytes), maximum: 9.31 GiB.: While executing GenerateRandom. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000023ab58e9 5. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3cbc 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::alloc<>(unsigned long) @ 0x0000000017cc83d4 10. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000017cc6ea7 11. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:385: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x0000000030418783 12. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:270: DB::fillColumnWithRandomData(std::shared_ptr, unsigned long, unsigned long, unsigned long, pcg_detail::engine, false, pcg_detail::specific_stream, pcg_detail::default_multiplier>&, std::shared_ptr) @ 0x000000003041b749 13. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:580: DB::(anonymous namespace)::GenerateSource::generate() @ 0x000000003042389c 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:49.659707 [ 18510 ] {64c7a837-91e4-4fbf-81d3-c1d59e1ba815} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 77, line 26) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:49.685681 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:50.109697 [ 45124 ] {52da1b8c-354c-469b-921d-9bc71eb37f5d} executeQuery: Code: 60. DB::Exception: Table test_gyxtnhd1.invalid_test_table_join does not exist: In scope WITH 'invalid_test_table_join' AS join_table SELECT joinGet(join_table, 'value', toUInt64(0)). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36876) (comment: 02384_analyzer_dict_get_join_get.sql) (query 23, line 57) (in query: WITH 'invalid_test_table_join' AS join_table SELECT joinGet(join_table, 'value', toUInt64(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. DB::(anonymous namespace)::getJoin(std::vector> const&, std::shared_ptr) @ 0x0000000017ce1c49 9. DB::(anonymous namespace)::JoinGetOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x0000000017ce05ca 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceba06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:52:50.119372 [ 45124 ] {} TCPHandler: Code: 60. DB::Exception: Table test_gyxtnhd1.invalid_test_table_join does not exist: In scope WITH 'invalid_test_table_join' AS join_table SELECT joinGet(join_table, 'value', toUInt64(0)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. DB::(anonymous namespace)::getJoin(std::vector> const&, std::shared_ptr) @ 0x0000000017ce1c49 9. DB::(anonymous namespace)::JoinGetOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x0000000017ce05ca 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceba06 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:52:51.688814 [ 46014 ] {5df3e51c-6d12-4927-af78-daba98faa60a} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36994) (comment: 02155_binary_op_between_float_and_decimal.sql) (query 13, line 17) (in query: CREATE TABLE t(d1 Decimal32(5), d2 Decimal64(10), d3 Decimal128(20), d4 Decimal256(40), f1 Float32, f2 Float64) ENGINE=Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:51.706751 [ 46014 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:52.674590 [ 18510 ] {7eac9394-25cc-4d7f-89f5-08cc4e9d8d2d} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 89, line 30) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:52.695384 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:52:52.745868 [ 46014 ] {b4185356-b85a-45b7-a67c-65c7036a9881} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37046) (comment: 00725_ipv4_ipv6_domains.sql) (query 2, line 3) (in query: -- Only valid values for IPv4 CREATE TABLE ipv4_test (ipv4_ IPv4) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:52.773377 [ 46014 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:53.463655 [ 46014 ] {eff9266c-9b14-4a51-ae43-e8f34e7d41f8} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40498) (comment: 02783_date_predicate_optimizations.sql) (query 1, line 1) (in query: CREATE TABLE source (`ts` DateTime('UTC'), `n` Int32) ENGINE = MergeTree PARTITION BY toYYYYMM(ts) ORDER BY tuple() SETTINGS index_granularity = 64311, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 7, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 521943396, compact_parts_max_granules_to_buffer = 18, compact_parts_merge_max_bytes_to_prefetch_part = 22877207, merge_max_block_size = 22849, 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 = 61, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 2417512, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 43934, primary_key_compress_block_size = 73563, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:53.472644 [ 46014 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:54.192034 [ 46014 ] {d7472aa6-46a2-45d6-b942-4076eca5e24b} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT ignore(addHours(now64(3), inf)) FROM numbers(2). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40506) (comment: 01773_datetime64_add_ubsan.sql) (query 1, line 1) (in query: -- The result is unspecified but UBSan should not argue. SELECT ignore(addHours(now64(3), inf)) FROM numbers(2);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. long DB::Processor::checkOverflow(double) @ 0x0000000018dbe3d7 6. void DB::Processor::vectorVector, DB::ColumnDecimal, DB::ColumnVector>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dcffe0 7. void DB::Processor::vectorVector, DB::ColumnDecimal>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dccccb 8. DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018db9d09 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018db75a7 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:52:54.213399 [ 46014 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT ignore(addHours(now64(3), inf)) FROM numbers(2). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. long DB::Processor::checkOverflow(double) @ 0x0000000018dbe3d7 6. void DB::Processor::vectorVector, DB::ColumnDecimal, DB::ColumnVector>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dcffe0 7. void DB::Processor::vectorVector, DB::ColumnDecimal>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x0000000018dccccb 8. DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x0000000018db9d09 9. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018db75a7 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 2025.06.13 15:52:54.623299 [ 8101 ] {17792369-0f8d-4255-8a59-6dcaf28186b1} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 20.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37024) (comment: 02155_read_in_order_max_rows_to_read.sql) (query 10, line 20) (in query: SELECT a FROM t_max_rows_to_read ORDER BY a LIMIT 20 FORMAT Null SETTINGS max_rows_to_read = 12;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3ace5b 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:52:54.632756 [ 8101 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 20.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3ace5b 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:54.830805 [ 8101 ] {de296e79-2a66-44ab-8a8d-b7ffd37879b5} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 92.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37024) (comment: 02155_read_in_order_max_rows_to_read.sql) (query 11, line 21) (in query: SELECT a FROM t_max_rows_to_read WHERE a > 10 ORDER BY a LIMIT 5 FORMAT Null SETTINGS max_rows_to_read = 12;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3ace5b 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:52:54.841313 [ 8101 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 92.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x000000002c3ace5b 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003182fa44 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:52:54.972214 [ 8101 ] {7cf1ef93-a643-4dd4-90ce-282d1bfef09d} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 4.00, current rows: 12.00. (TOO_MANY_ROWS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37024) (comment: 02155_read_in_order_max_rows_to_read.sql) (query 12, line 22) (in query: SELECT a FROM t_max_rows_to_read WHERE a = 10 OR a = 20 FORMAT Null SETTINGS max_rows_to_read = 4;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003218d1b0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0c69 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:52:55.032383 [ 8101 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 4.00, current rows: 12.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002c3ef42f 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002c3ee809 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003218d1b0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2110: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0c69 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:52:56.840725 [ 46014 ] {100a4cbe-ff5c-4690-8f40-d9fbb7ab9b0d} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40518) (comment: 03221_mutate_profile_events.sh) (query 2, line 4) (in query: CREATE TABLE t_mutate_profile_events (key UInt64, id UInt64, v1 UInt64, v2 UInt64) ENGINE = MergeTree ORDER BY id PARTITION BY key SETTINGS min_bytes_for_wide_part = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:56.859334 [ 46014 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:57.865418 [ 18510 ] {2740e274-dd5c-4288-921d-ca6cc2fd69d8} 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.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 110, line 37) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c90b7a 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c5245 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:52:57.889662 [ 18510 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1922: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c90b7a 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:161: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c5245 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:52:58.115754 [ 18510 ] {37e70e6a-8125-4e59-83c2-74f7d1ea6be2} executeQuery: Code: 60. DB::Exception: Table test_1.mt_00763_2 does not exist. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 111, line 37) (in query: INSERT INTO mt_00763_2 SELECT toString(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:52:58.119997 [ 18510 ] {} TCPHandler: Code: 60. DB::Exception: Table test_1.mt_00763_2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d5f03 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:00.430791 [ 3500 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {453fc51f-5cbc-4868-8840-cc98ab0f3eb2::202506_118_155_7}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab57af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab1fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003122f56b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d8e4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:53:01.804852 [ 44676 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:53:02.173784 [ 18510 ] {dd2985d5-f15f-46a1-bc4a-9371d460f9ea} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 128, line 43) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:02.185768 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:04.672377 [ 44676 ] {03f21ecf-c673-4c1d-91c7-5cbb0374f712} executeQuery: Code: 43. DB::Exception: Illegal type String expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44070) (comment: 01702_system_numbers_scientific_notation.sql) (query 3, line 3) (in query: select * from numbers_mt('100') format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a1166 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002849fee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:53:04.699979 [ 44676 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:105: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a1166 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002849fee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:53:04.932617 [ 44676 ] {3c325f85-f18b-42ac-afd0-727d172eaeed} executeQuery: Code: 43. DB::Exception: The value inf is not representable as UInt64. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44070) (comment: 01702_system_numbers_scientific_notation.sql) (query 4, line 4) (in query: select * from numbers_mt(inf) format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a1243 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002849fee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:53:04.947183 [ 44676 ] {} TCPHandler: Code: 43. DB::Exception: The value inf is not representable as UInt64. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a1243 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002849fee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:53:05.008104 [ 44676 ] {0d1129ae-4686-4b98-93ad-6db4ba1a741d} executeQuery: Code: 43. DB::Exception: The value nan is not representable as UInt64. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44070) (comment: 01702_system_numbers_scientific_notation.sql) (query 5, line 5) (in query: select * from numbers_mt(nan) format Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a1243 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002849fee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:53:05.018395 [ 44676 ] {} TCPHandler: Code: 43. DB::Exception: The value nan is not representable as UInt64. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:109: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000284a1243 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002849fee9 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002b3dc06f 8. ./build_docker/./src/Interpreters/Context.cpp:2505: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002d485d7b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4971: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc0cb35 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:53:06.907895 [ 18510 ] {a64c5740-8694-4b95-95fe-6f1bb63e91d4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=936, jobs=864). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 141, line 47) (in query: INSERT INTO mt_00763_2 SELECT toString(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 8. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:53:06.945393 [ 18510 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=936, jobs=864). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 8. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:53:10.208706 [ 18510 ] {331e5ba6-1f54-4c0f-b66c-41dc472d0b4c} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 152, line 51) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:10.217431 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:15.436179 [ 18510 ] {ad07da14-af07-47d9-96bc-5fe09f6b9a51} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 170, line 57) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:15.448578 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:20.551471 [ 18377 ] {beea3332-0162-447d-9fbf-73a54c17893a} executeQuery: Code: 36. DB::Exception: Bidirectional can only be applied to hierarchical attributes. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55144) (comment: 02294_dictionaries_hierarchical_index.sql) (query 5, line 11) (in query: CREATE DICTIONARY hierarchy_flat_dictionary_index ( id UInt64, parent_id UInt64 BIDIRECTIONAL ) PRIMARY KEY id SOURCE(CLICKHOUSE(TABLE 'test_hierarchy_source_table')) LAYOUT(FLAT()) LIFETIME(0);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:365: DB::DictionaryStructure::getAttributes(Poco::Util::AbstractConfiguration const&, String const&, bool) @ 0x000000002acdf711 6. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:97: DB::DictionaryStructure::DictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x000000002acdca30 7. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:214: DB::ExternalDictionariesLoader::getDictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x000000002dbe45fb 8. ./build_docker/./src/Storages/StorageDictionary.cpp:143: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000003037c1a1 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageDictionary* std::construct_at[abi:ne190107]&, std::shared_ptr&, DB::StorageDictionary*>(DB::StorageDictionary*, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000030381e31 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, std::allocator, 0>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000030381c1f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000030381a4c 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003038063e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:53:20.586452 [ 18377 ] {} TCPHandler: Code: 36. DB::Exception: Bidirectional can only be applied to hierarchical attributes. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:365: DB::DictionaryStructure::getAttributes(Poco::Util::AbstractConfiguration const&, String const&, bool) @ 0x000000002acdf711 6. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:97: DB::DictionaryStructure::DictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x000000002acdca30 7. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:214: DB::ExternalDictionariesLoader::getDictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x000000002dbe45fb 8. ./build_docker/./src/Storages/StorageDictionary.cpp:143: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000003037c1a1 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageDictionary* std::construct_at[abi:ne190107]&, std::shared_ptr&, DB::StorageDictionary*>(DB::StorageDictionary*, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000030381e31 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr&, std::allocator, 0>(std::allocator, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000030381c1f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000030381a4c 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003038063e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:53:21.788584 [ 18510 ] {56632201-decb-4305-a3f5-108593b2ef15} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 191, line 64) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:21.825248 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:23.248618 [ 18510 ] {3af8b4af-97cc-41e5-9c54-074d6b3aa106} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 197, line 66) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:23.277231 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:23.305619 [ 46553 ] {2507436d-9881-42ea-9714-c96cbd8e4da1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55100) (comment: 00094_union_race_conditions_5.sh) (query 10, line 10) (in query: SELECT * FROM system.numbers_mt LIMIT 111;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:53:23.318338 [ 46553 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:53:27.765541 [ 4172 ] {c967df67-e4f9-4259-84de-6fc0bc5ac893} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48068) (comment: 00094_union_race_conditions_5.sh) (query 13, line 13) (in query: SELECT * FROM system.numbers_mt LIMIT 111;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:53:27.850336 [ 4172 ] {} TCPHandler: 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:53:28.752255 [ 6236 ] {d3a3e897-82aa-4d1c-965b-423bcdf00bbb} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toUnixTimestamp(toDateTime64('1900-12-12 11:22:33', 0, 'UTC')). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48154) (comment: 01768_extended_range.sql) (query 4, line 4) (in query: SELECT toUnixTimestamp(toDateTime64('1900-12-12 11:22:33', 0, 'UTC'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl(DB::DateTime64 const&, unsigned int, unsigned int&) @ 0x000000002c4a45ee 6. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>(T::FieldType const&, unsigned int) @ 0x000000002c4ac659 7. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUnixTimestamp, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b22bf5f 8. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b2259a6 9. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, 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::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02e6b7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b067c1e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b066a83 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:53:28.758631 [ 6236 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toUnixTimestamp(toDateTime64('1900-12-12 11:22:33', 0, 'UTC')). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl(DB::DateTime64 const&, unsigned int, unsigned int&) @ 0x000000002c4a45ee 6. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>(T::FieldType const&, unsigned int) @ 0x000000002c4ac659 7. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUnixTimestamp, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002b22bf5f 8. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b2259a6 9. ./src/Core/callOnTypeIndex.h:278: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, 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::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02e6b7 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b067c1e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUnixTimestamp, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b066a83 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 2025.06.13 15:53:36.287124 [ 6236 ] {f4ee8756-89b5-4bd6-9bd2-aedc66a3f3a9} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43650) (comment: 02935_format_with_arbitrary_types.sql) (query 1, line 2) (in query: -- Tags: no-fasttest -- no-fasttest: json type needs rapidjson library, geo types need s2 geometry SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:36.314693 [ 6236 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:37.592846 [ 3509 ] {ca4f3309-a731-4074-8e76-b543813bed4d::202506_286_296_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c14c18 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c06f6e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:53:37.594284 [ 3509 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ca4f3309-a731-4074-8e76-b543813bed4d::202506_286_296_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c14c18 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c06f6e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:53:38.030052 [ 46451 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:53:38.894563 [ 45084 ] {54af6d30-53fd-47fa-8d0e-3320408c6761} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=936, jobs=860). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48172) (comment: 00094_union_race_conditions_5.sh) (query 59, line 59) (in query: SELECT * FROM system.numbers_mt LIMIT 111;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:38.945632 [ 45084 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=936, jobs=860). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:41.313203 [ 34302 ] {7586683a-55b6-418e-8449-5133dda3609d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48222) (comment: 02911_backup_restore_keeper_map.sh) (query 1, line 1) (in query: DROP DATABASE test_jn1gj4rw_02911_keeper_map SYNC;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:41.336906 [ 34302 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:42.498657 [ 46451 ] {0fd0fd1a-52e4-4b6e-a5f7-696112bc4263} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43806) (comment: 02274_full_sort_join_nodistinct.gen.sql) (query 5, line 8) (in query: CREATE TABLE t1 (`key` UInt32, `s` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 13682, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 364095320, compact_parts_max_granules_to_buffer = 200, compact_parts_merge_max_bytes_to_prefetch_part = 1886816, merge_max_block_size = 11920, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1149978765, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 2313432745, index_granularity_bytes = 16855484, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 46, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 8343, primary_key_compress_block_size = 46008, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:42.510425 [ 46451 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:43.095121 [ 6219 ] {f8ee5869-7526-4b61-98a5-9187ec4b88d4} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:33182). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:33182) (comment: 01851_hedged_connections_external_tables.sql) (query 1, line 2) (in query: DESC TABLE numbers(2)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b951d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:53:43.107738 [ 6219 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:33182). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:1291: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b951d 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:53:43.504983 [ 45683 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:43.506346 [ 45683 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:53:43.535903 [ 8099 ] {ffb9d98f-6c90-41df-8db3-e785721bda3f} executeQuery: Code: 210. DB::Exception: Connection reset by peer, while writing to socket (127.0.0.1:58838 -> 127.0.0.2:9000): While executing Remote. (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43830) (comment: 01851_hedged_connections_external_tables.sql) (query 1, line 2) (in query: select number from remote('127.0.0.{3|2}', numbers(2)) where number global in (select number from numbers(1)) settings async_socket_for_remote=1, use_hedged_requests = 1, sleep_in_send_data_ms=10, receive_data_timeout_ms=1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Client/Connection.cpp:986: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003148677f 7. ./build_docker/./src/Client/Connection.cpp:1174: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x000000003148a88d 8. ./build_docker/./src/Client/HedgedConnections.cpp:134: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&)::$_0::operator()(DB::HedgedConnections::ReplicaState&) const @ 0x00000000314cab1d 9. ./build_docker/./src/Client/HedgedConnections.cpp:140: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x00000000314ca4de 10. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:938: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002c3b5355 11. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:447: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002c3b30dd 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3ea61f 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 14. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 16. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:53:43.553784 [ 8099 ] {} TCPHandler: Code: 210. DB::Exception: Connection reset by peer, while writing to socket (127.0.0.1:58838 -> 127.0.0.2:9000): While executing Remote. (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Client/Connection.cpp:986: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003148677f 7. ./build_docker/./src/Client/Connection.cpp:1174: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x000000003148a88d 8. ./build_docker/./src/Client/HedgedConnections.cpp:134: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&)::$_0::operator()(DB::HedgedConnections::ReplicaState&) const @ 0x00000000314cab1d 9. ./build_docker/./src/Client/HedgedConnections.cpp:140: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x00000000314ca4de 10. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:938: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002c3b5355 11. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:447: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002c3b30dd 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3ea61f 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 14. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 16. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:53:45.806883 [ 18510 ] {4635b433-5be8-400d-a8a8-d3258c36f5e7} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 260, line 87) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:45.842055 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:46.036321 [ 45511 ] {72f81988-59aa-409c-af15-a0bbc4d97f85} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42224) (comment: 00753_alter_attach.sql) (in query: DROP DATABASE IF EXISTS test_mv82wkd7 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:53:46.039229 [ 45511 ] {72f81988-59aa-409c-af15-a0bbc4d97f85} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:53:46.106384 [ 7755 ] {01bccde1-f8e8-476a-b0b1-edf861f6176a} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42732) (comment: 00365_statistics_in_formats.sh) (query 1, line 1) (in query: CREATE TABLE numbers (`number` UInt64) ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 61009, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.31540143489837646, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 520409803, compact_parts_max_bytes_to_buffer = 266716231, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 9814539, merge_max_block_size = 4014, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1139129900, 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 = 6735708, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 59871, primary_key_compress_block_size = 61395, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:46.132039 [ 7755 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:46.236987 [ 45124 ] {421b589c-6210-4ea9-81a8-6900a086a452} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36910) (comment: 00753_alter_attach.sql) (in query: DROP DATABASE IF EXISTS test_mv82wkd7 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:53:46.245096 [ 45124 ] {421b589c-6210-4ea9-81a8-6900a086a452} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:53:46.420033 [ 18510 ] {b8a626bb-4e70-4475-86bb-258201dd5100} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 263, line 88) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:46.437254 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:46.739333 [ 46648 ] {1520edf7-7ada-4bfe-a49e-c7f6374ce8dd} executeQuery: Code: 60. DB::Exception: Table test_5.numbers does not exist. Maybe you meant system.numbers?. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42766) (comment: 00365_statistics_in_formats.sh) (query 1, line 1) (in query: INSERT INTO numbers select * from system.numbers limit 10), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:46.773807 [ 46648 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.numbers does not exist. Maybe you meant system.numbers?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002c7d60a7 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000002d5ea17e 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000002d5f0d12 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002dcd9b64 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5717 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:47.324556 [ 8431 ] {7dfd485f-65ac-46bf-970d-3ea220b53998} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT number FROM numbers LIMIT 10. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42792) (comment: 00365_statistics_in_formats.sh) (query 1, line 1) (in query: SELECT number FROM numbers LIMIT 10 FORMAT JSON), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:53:47.369518 [ 8431 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT number FROM numbers LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:53:47.600646 [ 44676 ] {be09f4af-5624-4cd4-994a-279219c2bf48} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42808) (comment: 02703_explain_query_tree_is_forbidden_with_old_analyzer.sql) (query 1, line 1) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:47.617740 [ 44676 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000001c1c938f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea9f81 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002bea965f 8. ./build_docker/./src/Interpreters/Context.cpp:2726: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002d488fe1 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x000000002de232ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:47.955013 [ 18510 ] {aaac11b8-b99f-4800-a42b-2f043bb4f4b0} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 269, line 90) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:47.964236 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:48.027094 [ 8099 ] {093dce34-e89c-4492-9a13-55c3e5c18796} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT number FROM numbers LIMIT 10. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42814) (comment: 00365_statistics_in_formats.sh) (query 1, line 1) (in query: SELECT number FROM numbers LIMIT 10 FORMAT JSONCompact), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:53:48.046631 [ 8099 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT number FROM numbers LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:53:48.358183 [ 42483 ] {} ExternalDictionariesLoader: Could not update external dictionary '61e0d5b5-88ca-4299-b8ed-7f0a0cbb8581', leaving the previous version, next update is scheduled at 2025-06-13 15:53:54: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000030f585dc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030f5af07 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000030f54898 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f54302 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dd53bf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dcd2b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000321e80e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003222601e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d4c3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003181a643 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000031836354 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003183653d 30. DB::FlatDictionary::loadData() @ 0x0000000028a43c8b 31. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000028a434fb (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:53:48.662292 [ 4163 ] {147a465b-4ac0-45b2-b861-9ec1a37e6315} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT number FROM numbers LIMIT 10. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42844) (comment: 00365_statistics_in_formats.sh) (query 1, line 1) (in query: SELECT number FROM numbers LIMIT 10 FORMAT XML), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:53:48.687270 [ 4163 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT number FROM numbers LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:53:48.727063 [ 5112 ] {d8be1aa8-72d1-4b2d-abf9-44a5215665c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 0, should be 1: In scope SELECT byteSwap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43822) (comment: 02887_byteswap.sql) (query 34, line 46) (in query: -- Number of arguments should equal 1 SELECT byteSwap();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:53:48.750124 [ 5112 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 0, should be 1: In scope SELECT byteSwap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:53:48.885388 [ 5112 ] {15b0e081-c988-47cf-a845-387ea4afed65} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(128, 129). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43822) (comment: 02887_byteswap.sql) (query 35, line 48) (in query: SELECT byteSwap(128, 129);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:53:48.894031 [ 5112 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(128, 129). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.077851 [ 8101 ] {f6f876f0-b864-4dbc-9958-cf95bb26cbb7} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT number FROM numbers LIMIT 10. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59368) (comment: 00365_statistics_in_formats.sh) (in query: SELECT number FROM numbers LIMIT 10 FORMAT JSON), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.088459 [ 8101 ] {f6f876f0-b864-4dbc-9958-cf95bb26cbb7} DynamicQueryHandler: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT number FROM numbers LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:53:49.109805 [ 5112 ] {5f546e8a-324b-4640-878f-90ea75d2f024} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function byteSwap: In scope SELECT byteSwap('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43822) (comment: 02887_byteswap.sql) (query 36, line 50) (in query: -- Input should be integral SELECT byteSwap('abc');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.116248 [ 5112 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function byteSwap: In scope SELECT byteSwap('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.342875 [ 5112 ] {bc1656a2-1c1a-4fa3-b73d-03e83f609800} executeQuery: Code: 43. DB::Exception: Illegal type FixedString(3) of argument of function byteSwap: In scope SELECT byteSwap(toFixedString('abc', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43822) (comment: 02887_byteswap.sql) (query 37, line 52) (in query: SELECT byteSwap(toFixedString('abc', 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.343323 [ 46553 ] {a40fc2db-47d9-451c-84fc-7ff78a340d6d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT number FROM numbers LIMIT 10. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59374) (comment: 00365_statistics_in_formats.sh) (in query: SELECT number FROM numbers LIMIT 10 FORMAT JSONCompact), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.347770 [ 5112 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type FixedString(3) of argument of function byteSwap: In scope SELECT byteSwap(toFixedString('abc', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.348475 [ 46553 ] {a40fc2db-47d9-451c-84fc-7ff78a340d6d} DynamicQueryHandler: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT number FROM numbers LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:53:49.393333 [ 3395 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:920: DB::StorageBuffer::flushAllBuffers(bool) @ 0x000000003088c01c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1094: DB::StorageBuffer::backgroundFlush() @ 0x00000000308923d8 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:53:49.464130 [ 5112 ] {fbe10265-2b8c-411e-85ce-495f208541ff} executeQuery: Code: 43. DB::Exception: Illegal type Date of argument of function byteSwap: In scope SELECT byteSwap(toDate('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43822) (comment: 02887_byteswap.sql) (query 38, line 53) (in query: SELECT byteSwap(toDate('2019-01-01'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.475430 [ 5112 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of argument of function byteSwap: In scope SELECT byteSwap(toDate('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.493321 [ 8431 ] {664d7d5c-27e0-401f-ac01-1ef21b747feb} StorageBuffer (test_ith5az1j.buffer_table1): Destination table test_ith5az1j.merge_tree_table1 has different type of column s (LowCardinality(String) != String). Data from destination table are converted. 2025.06.13 15:53:49.529007 [ 34370 ] {0f4e43dc-6073-42c7-ba38-00455dd03894} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT number FROM numbers LIMIT 10. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59390) (comment: 00365_statistics_in_formats.sh) (in query: SELECT number FROM numbers LIMIT 10 FORMAT XML), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.537629 [ 34370 ] {0f4e43dc-6073-42c7-ba38-00455dd03894} DynamicQueryHandler: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT number FROM numbers LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4371: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4dfb1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:53:49.565173 [ 5112 ] {43d40990-9f5f-4809-a796-09e496b5b106} executeQuery: Code: 43. DB::Exception: Illegal type Date32 of argument of function byteSwap: In scope SELECT byteSwap(toDate32('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43822) (comment: 02887_byteswap.sql) (query 39, line 54) (in query: SELECT byteSwap(toDate32('2019-01-01'));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.626148 [ 5112 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date32 of argument of function byteSwap: In scope SELECT byteSwap(toDate32('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.710622 [ 5112 ] {3b8e6b5b-ddac-4a61-b412-419923e6ea52} executeQuery: Code: 43. DB::Exception: Illegal type DateTime of argument of function byteSwap: In scope SELECT byteSwap(toDateTime32(1546300800)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43822) (comment: 02887_byteswap.sql) (query 40, line 55) (in query: SELECT byteSwap(toDateTime32(1546300800));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.733513 [ 5112 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime of argument of function byteSwap: In scope SELECT byteSwap(toDateTime32(1546300800)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.922342 [ 5112 ] {0c285db7-43fe-4d00-99ac-20902162dc2d} executeQuery: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument of function byteSwap: In scope SELECT byteSwap(toDateTime64(1546300800, 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43822) (comment: 02887_byteswap.sql) (query 41, line 56) (in query: SELECT byteSwap(toDateTime64(1546300800, 3));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:49.930636 [ 5112 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument of function byteSwap: In scope SELECT byteSwap(toDateTime64(1546300800, 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:50.070177 [ 5112 ] {f6070bba-b9e7-4091-92b2-14da957accfd} executeQuery: Code: 43. DB::Exception: Illegal type UUID of argument of function byteSwap: In scope SELECT byteSwap(generateUUIDv4()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43822) (comment: 02887_byteswap.sql) (query 42, line 57) (in query: SELECT byteSwap(generateUUIDv4());), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:50.091777 [ 5112 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UUID of argument of function byteSwap: In scope SELECT byteSwap(generateUUIDv4()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:50.215812 [ 8431 ] {7af0604c-f8ae-4d66-a944-3c1bea1eb3fe} StorageBuffer (test_ith5az1j.buffer_table1): Destination table test_ith5az1j.merge_tree_table1 has different type of column s (LowCardinality(String) != String). Data from destination table are converted. 2025.06.13 15:53:50.229389 [ 5112 ] {7efc1cb4-563f-4b16-8294-a68485830364} executeQuery: Code: 43. DB::Exception: Illegal type Decimal(9, 4) of argument of function byteSwap: In scope SELECT byteSwap(toDecimal32(2, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43822) (comment: 02887_byteswap.sql) (query 43, line 58) (in query: SELECT byteSwap(toDecimal32(2, 4));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:50.236921 [ 5112 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Decimal(9, 4) of argument of function byteSwap: In scope SELECT byteSwap(toDecimal32(2, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000019e97db0 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017cbd934 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:50.484245 [ 8431 ] {2399dac2-ba2e-4209-8e11-b910db54ba25} StorageBuffer (test_ith5az1j.buffer_table1): Destination table test_ith5az1j.merge_tree_table1 has different type of column s (LowCardinality(String) != String). Data from destination table are converted. 2025.06.13 15:53:50.529206 [ 5112 ] {3051403f-360b-4004-939d-93608c565a2b} executeQuery: Code: 48. DB::Exception: byteSwap() is not implemented for float datatype: In scope SELECT byteSwap(toFloat32(123.456)). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43822) (comment: 02887_byteswap.sql) (query 44, line 59) (in query: SELECT byteSwap(toFloat32(123.456));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::(anonymous namespace)::ByteSwapImpl::apply(float) @ 0x0000000019ea1a26 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x0000000019ea1891 6. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x0000000019e9b8ba 7. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS1_IfEENS1_IdEENS_15DataTypeDecimalINS_7DecimalIiEEEENSN_INSO_IlEEEENSN_INSO_ISH_EEEENSN_INSO_ISJ_EEEENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZNKS_23FunctionUnaryArithmeticINS_12_GLOBAL__N_112ByteSwapImplENS12_12NameByteSwapELb1EE11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS16_9allocatorIS18_EEEERKNS16_10shared_ptrIKS10_EEmEUlRKT_E_EEbPKT0_OT1_ @ 0x0000000019e99f3c 8. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019e97173 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:53:50.539189 [ 5112 ] {} TCPHandler: Code: 48. DB::Exception: byteSwap() is not implemented for float datatype: In scope SELECT byteSwap(toFloat32(123.456)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::(anonymous namespace)::ByteSwapImpl::apply(float) @ 0x0000000019ea1a26 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x0000000019ea1891 6. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x0000000019e9b8ba 7. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS1_IfEENS1_IdEENS_15DataTypeDecimalINS_7DecimalIiEEEENSN_INSO_IlEEEENSN_INSO_ISH_EEEENSN_INSO_ISJ_EEEENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZNKS_23FunctionUnaryArithmeticINS_12_GLOBAL__N_112ByteSwapImplENS12_12NameByteSwapELb1EE11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS16_9allocatorIS18_EEEERKNS16_10shared_ptrIKS10_EEmEUlRKT_E_EEbPKT0_OT1_ @ 0x0000000019e99f3c 8. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019e97173 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:53:50.743017 [ 5112 ] {50032fda-e103-4072-ba3c-8f198419b953} executeQuery: Code: 48. DB::Exception: byteSwap() is not implemented for double datatype: In scope SELECT byteSwap(toFloat64(123.456)). (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43822) (comment: 02887_byteswap.sql) (query 45, line 60) (in query: SELECT byteSwap(toFloat64(123.456));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::(anonymous namespace)::ByteSwapImpl::apply(double) @ 0x0000000019ea1e46 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x0000000019ea1cb1 6. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x0000000019e9bc3a 7. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS1_IfEENS1_IdEENS_15DataTypeDecimalINS_7DecimalIiEEEENSN_INSO_IlEEEENSN_INSO_ISH_EEEENSN_INSO_ISJ_EEEENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZNKS_23FunctionUnaryArithmeticINS_12_GLOBAL__N_112ByteSwapImplENS12_12NameByteSwapELb1EE11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS16_9allocatorIS18_EEEERKNS16_10shared_ptrIKS10_EEmEUlRKT_E_EEbPKT0_OT1_ @ 0x0000000019e99f7c 8. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019e97173 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:53:50.755840 [ 5112 ] {} TCPHandler: Code: 48. DB::Exception: byteSwap() is not implemented for double datatype: In scope SELECT byteSwap(toFloat64(123.456)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::(anonymous namespace)::ByteSwapImpl::apply(double) @ 0x0000000019ea1e46 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x0000000019ea1cb1 6. auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x0000000019e9bc3a 7. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS1_IfEENS1_IdEENS_15DataTypeDecimalINS_7DecimalIiEEEENSN_INSO_IlEEEENSN_INSO_ISH_EEEENSN_INSO_ISJ_EEEENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZNKS_23FunctionUnaryArithmeticINS_12_GLOBAL__N_112ByteSwapImplENS12_12NameByteSwapELb1EE11executeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS16_9allocatorIS18_EEEERKNS16_10shared_ptrIKS10_EEmEUlRKT_E_EEbPKT0_OT1_ @ 0x0000000019e99f7c 8. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019e97173 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:53:51.928264 [ 18510 ] {91e39277-45bd-4664-88d0-63f4c0c5e022} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 284, line 95) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:51.955109 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:54.823195 [ 46553 ] {0e2455b6-463b-4413-8eab-35f4bc0f37ec} executeQuery: Code: 57. DB::Exception: Table test_g5bm38cx.tmp already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42938) (comment: 01943_query_id_check.sql) (query 11, line 18) (in query: CREATE TABLE tmp (str String) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:54.856236 [ 46553 ] {} TCPHandler: Code: 57. DB::Exception: Table test_g5bm38cx.tmp already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:55.428165 [ 18377 ] {4d46e661-6e5e-4711-ac32-7401f69af5ac} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42952) (comment: 01907_multiple_aliases.sql) (query 3, line 3) (in query: CREATE TABLE t (d Date, z UInt32) ENGINE = MergeTree(d, (z), 1);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:55.432623 [ 18377 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:55.702979 [ 18510 ] {56a6cbf6-9dbf-4cf7-9526-a516b021bbbe} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 302, line 101) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:55.708556 [ 45085 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:53:55.710498 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:53:55.710843 [ 45085 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Server/TCPHandler.cpp:896: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b6787 6. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:53:55.720293 [ 2860 ] {e508baa8-ea8a-4ea8-8a65-7ab2bae90f5e} executeQuery: Code: 452. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60688) (comment: 02947_parallel_replicas_remote.sql) (query 4, line 10) (in query: SELECT count(), sum(id) FROM remote('127.0.0.1|127.0.0.2|127.0.0.3|127.0.0.4', currentDatabase(), test) SETTINGS enable_parallel_replicas = 2, max_parallel_replicas = 4, prefer_localhost_replica = 0, parallel_replicas_for_non_replicated_merge_tree = 1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:53:55.747093 [ 2860 ] {} TCPHandler: Code: 452. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Setting max_execution_time shouldn't be greater than 60.. Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea9807 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/TCPHandler.cpp:2157: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000316c2796 11. ./build_docker/./src/Server/TCPHandler.cpp:917: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000316b63f7 12. ./build_docker/./src/Server/TCPHandler.cpp:490: DB::TCPHandler::runImpl() @ 0x00000000316a3619 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 : While executing Remote. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000031508879 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 8. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 10. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:53:57.387946 [ 34302 ] {6be2e5d2-b8db-4c09-80a4-f3d71d51e18f} 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.20286.altinityantalya (altinity build)) (from [::1]:60748) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2686e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cfce 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:53:57.407013 [ 34302 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2686e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cfce 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:53:57.564676 [ 34302 ] {14718d30-0cfa-40ef-ab54-c5d45cd48908} 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.20286.altinityantalya (altinity build)) (from [::1]:60748) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2686e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cfce 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:53:57.575380 [ 34302 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2686e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cfce 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:53:57.665548 [ 34302 ] {625d3409-e138-4968-90db-20017958459f} 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.20286.altinityantalya (altinity build)) (from [::1]:60748) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2686e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cfce 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:53:57.670689 [ 34302 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2686e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cfce 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:53:57.756835 [ 34302 ] {b03ef418-e9fe-43b7-b7fc-d47aaa8965f0} 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.20286.altinityantalya (altinity build)) (from [::1]:60748) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2686e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cfce 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:57.764976 [ 34302 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc2686e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3cfce 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3800: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3869: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0483f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5319: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fbe9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:53:58.829290 [ 3499 ] {491c9866-f7d9-4f23-b8a1-f8009bc022c4::202506_106_163_14} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1125: DB::MergeTask::VerticalMergeStage::createPipelineForReadingOneColumn(String const&) const @ 0x0000000030c1e97a 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1149: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000030c1faa2 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x0000000030c28ab4 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000030c27ad7 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:53:58.831072 [ 3499 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {491c9866-f7d9-4f23-b8a1-f8009bc022c4::202506_106_163_14}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1125: DB::MergeTask::VerticalMergeStage::createPipelineForReadingOneColumn(String const&) const @ 0x0000000030c1e97a 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1149: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x0000000030c1faa2 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x0000000030c28ab4 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x0000000030c27ad7 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26629 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:01.533333 [ 18510 ] {8e337de5-307f-4213-b8fc-c14f133a2f59} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 329, line 110) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:01.548027 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:01.696845 [ 3895 ] {26133a51-419f-420d-a2e8-071cc315292f} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60732) (comment: 02006_test_positional_arguments.sql) (query 5, line 7) (in query: create table test(x1 Int, x2 Int, x3 Int) engine=Memory();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:01.720939 [ 3895 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:02.067202 [ 18510 ] {d8e9d1cc-c4d6-4178-8064-a17ca3bb5296} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 332, line 111) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:02.073948 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:02.658476 [ 3710 ] {1e0d1218-39b1-4411-bbbc-928e710f5691} test_3.rmt1 (518d3cd7-921f-4f7d-9866-10349a9e76df): Part /var/lib/clickhouse/store/518/518d3cd7-921f-4f7d-9866-10349a9e76df/all_0_0_0_1/ is broken and needs manual correction. Reason: Code: 107. DB::Exception: store/518/518d3cd7-921f-4f7d-9866-10349a9e76df/all_0_0_0_1/data.bin doesn't exist: columns: columns format version: 1 2 columns: `a` Int32 `b` Int32 , getMarkSizeInBytes: 40, getMarksCount: 2, index_granularity_info: [mark_type: [adaptive: true, compressed: true, part_type: Compact], index_granularity_bytes: 7234755, fixed_index_granularity: 38490], index_granularity: [Adaptive(marks_rows_partial_sums: [3, 3])], part_state: [state: Temporary, is_unexpected_local_part: false, is_frozen: false, is_duplicate: false]. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, std::filesystem::path&&) @ 0x0000000030db740f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartChecksum.cpp:76: DB::MergeTreeDataPartChecksum::checkSize(DB::IDataPartStorage const&, String const&) const @ 0x0000000030db97fb 6. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2154: DB::IMergeTreeDataPart::checkConsistencyBase() const @ 0x0000000030b685a0 7. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2212: DB::IMergeTreeDataPart::checkConsistency(bool) const @ 0x0000000030b53320 8. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:864: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000030b4a3d5 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1594: DB::MergeTreeData::loadDataPart(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&) @ 0x0000000030c84616 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1733: DB::MergeTreeData::loadDataPartWithRetries(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&, unsigned long, unsigned long, unsigned long) @ 0x0000000030c8d09e 11. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1795: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000030d6608a 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1790: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000030c8e552 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1986: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c91681 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:530: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x000000003058bbaa 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x00000000311c3e69 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x00000000311c3bd4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd8cd 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:02.673288 [ 3710 ] {1e0d1218-39b1-4411-bbbc-928e710f5691} test_3.rmt1 (518d3cd7-921f-4f7d-9866-10349a9e76df): while loading part all_0_0_0_1 on path store/518/518d3cd7-921f-4f7d-9866-10349a9e76df/all_0_0_0_1: Code: 107. DB::Exception: store/518/518d3cd7-921f-4f7d-9866-10349a9e76df/all_0_0_0_1/data.bin doesn't exist: columns: columns format version: 1 2 columns: `a` Int32 `b` Int32 , getMarkSizeInBytes: 40, getMarksCount: 2, index_granularity_info: [mark_type: [adaptive: true, compressed: true, part_type: Compact], index_granularity_bytes: 7234755, fixed_index_granularity: 38490], index_granularity: [Adaptive(marks_rows_partial_sums: [3, 3])], part_state: [state: Temporary, is_unexpected_local_part: false, is_frozen: false, is_duplicate: false]: Part contains files: data.cmrk3 (58 bytes), primary.cidx (42 bytes), count.txt (1 bytes), checksums.txt (221 bytes), default_compression_codec.txt (10 bytes), columns.txt (57 bytes), metadata_version.txt (1 bytes). (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, std::filesystem::path&&) @ 0x0000000030db740f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartChecksum.cpp:76: DB::MergeTreeDataPartChecksum::checkSize(DB::IDataPartStorage const&, String const&) const @ 0x0000000030db97fb 6. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2154: DB::IMergeTreeDataPart::checkConsistencyBase() const @ 0x0000000030b685a0 7. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2212: DB::IMergeTreeDataPart::checkConsistency(bool) const @ 0x0000000030b53320 8. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:864: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000030b4a3d5 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1594: DB::MergeTreeData::loadDataPart(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&) @ 0x0000000030c84616 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1733: DB::MergeTreeData::loadDataPartWithRetries(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&, unsigned long, unsigned long, unsigned long) @ 0x0000000030c8d09e 11. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1795: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000030d6608a 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1790: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000030c8e552 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1986: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c91681 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:530: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x000000003058bbaa 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x00000000311c3e69 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x00000000311c3bd4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd8cd 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:02.675286 [ 3710 ] {1e0d1218-39b1-4411-bbbc-928e710f5691} test_3.rmt1 (518d3cd7-921f-4f7d-9866-10349a9e76df): Detaching broken part /var/lib/clickhouse/store/518/518d3cd7-921f-4f7d-9866-10349a9e76df/all_0_0_0_1 (size: 390.00 B). If it happened after update, it is likely because of backward incompatibility. You need to resolve this manually 2025.06.13 15:54:02.694079 [ 41539 ] {1e0d1218-39b1-4411-bbbc-928e710f5691} test_3.rmt1 (518d3cd7-921f-4f7d-9866-10349a9e76df): Part /var/lib/clickhouse/store/518/518d3cd7-921f-4f7d-9866-10349a9e76df/all_0_0_0/ is broken and needs manual correction. Reason: Code: 107. DB::Exception: store/518/518d3cd7-921f-4f7d-9866-10349a9e76df/all_0_0_0/data.bin doesn't exist: columns: columns format version: 1 2 columns: `a` Int32 `b` Int32 , getMarkSizeInBytes: 40, getMarksCount: 2, index_granularity_info: [mark_type: [adaptive: true, compressed: true, part_type: Compact], index_granularity_bytes: 7234755, fixed_index_granularity: 38490], index_granularity: [Adaptive(marks_rows_partial_sums: [3, 3])], part_state: [state: Temporary, is_unexpected_local_part: false, is_frozen: false, is_duplicate: false]. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, std::filesystem::path&&) @ 0x0000000030db740f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartChecksum.cpp:76: DB::MergeTreeDataPartChecksum::checkSize(DB::IDataPartStorage const&, String const&) const @ 0x0000000030db97fb 6. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2154: DB::IMergeTreeDataPart::checkConsistencyBase() const @ 0x0000000030b685a0 7. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2212: DB::IMergeTreeDataPart::checkConsistency(bool) const @ 0x0000000030b53320 8. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:864: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000030b4a3d5 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1594: DB::MergeTreeData::loadDataPart(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&) @ 0x0000000030c84616 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1733: DB::MergeTreeData::loadDataPartWithRetries(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&, unsigned long, unsigned long, unsigned long) @ 0x0000000030c8d09e 11. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1795: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000030d6608a 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1790: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000030c8e552 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1986: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c91681 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:530: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x000000003058bbaa 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x00000000311c3e69 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x00000000311c3bd4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd8cd 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:02.696968 [ 41539 ] {1e0d1218-39b1-4411-bbbc-928e710f5691} test_3.rmt1 (518d3cd7-921f-4f7d-9866-10349a9e76df): while loading part all_0_0_0 on path store/518/518d3cd7-921f-4f7d-9866-10349a9e76df/all_0_0_0: Code: 107. DB::Exception: store/518/518d3cd7-921f-4f7d-9866-10349a9e76df/all_0_0_0/data.bin doesn't exist: columns: columns format version: 1 2 columns: `a` Int32 `b` Int32 , getMarkSizeInBytes: 40, getMarksCount: 2, index_granularity_info: [mark_type: [adaptive: true, compressed: true, part_type: Compact], index_granularity_bytes: 7234755, fixed_index_granularity: 38490], index_granularity: [Adaptive(marks_rows_partial_sums: [3, 3])], part_state: [state: Temporary, is_unexpected_local_part: false, is_frozen: false, is_duplicate: false]: Part contains files: data.cmrk3 (58 bytes), primary.cidx (42 bytes), count.txt (1 bytes), checksums.txt (221 bytes), default_compression_codec.txt (10 bytes), columns.txt (57 bytes), metadata_version.txt (1 bytes). (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, std::filesystem::path&&) @ 0x0000000030db740f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartChecksum.cpp:76: DB::MergeTreeDataPartChecksum::checkSize(DB::IDataPartStorage const&, String const&) const @ 0x0000000030db97fb 6. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2154: DB::IMergeTreeDataPart::checkConsistencyBase() const @ 0x0000000030b685a0 7. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2212: DB::IMergeTreeDataPart::checkConsistency(bool) const @ 0x0000000030b53320 8. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:864: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000030b4a3d5 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1594: DB::MergeTreeData::loadDataPart(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&) @ 0x0000000030c84616 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1733: DB::MergeTreeData::loadDataPartWithRetries(DB::MergeTreePartInfo const&, String const&, std::shared_ptr const&, DB::MergeTreeDataPartState, std::mutex&, unsigned long, unsigned long, unsigned long) @ 0x0000000030c8d09e 11. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1795: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000030d6608a 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1790: DB::MergeTreeData::loadDataPartsFromDisk(std::vector, std::allocator>>&) @ 0x0000000030c8e552 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1986: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000030c91681 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:530: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x000000003058bbaa 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, std::allocator, 0>(std::allocator, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x00000000311c3e69 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x00000000311c3bd4 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd8cd 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:02.698731 [ 41539 ] {1e0d1218-39b1-4411-bbbc-928e710f5691} test_3.rmt1 (518d3cd7-921f-4f7d-9866-10349a9e76df): Detaching broken part /var/lib/clickhouse/store/518/518d3cd7-921f-4f7d-9866-10349a9e76df/all_0_0_0 (size: 390.00 B). If it happened after update, it is likely because of backward incompatibility. You need to resolve this manually 2025.06.13 15:54:05.565144 [ 18615 ] {90c7aeba-b475-4856-8495-13f77a62db5d} 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.20286.altinityantalya (altinity build)) (from [::1]:60932) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:562: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213e431 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:54:05.571357 [ 18615 ] {} TCPHandler: Code: 403. DB::Exception: Cannot convert JOIN ON expression to CROSS JOIN, because hash join is disabled. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:562: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213e431 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:54:05.589276 [ 3838 ] {27334353-2049-4ae3-9dd5-d98a902ab1ec} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:60904) (comment: 02366_explain_query_tree.sql) (query 4, line 7) (in query: DROP TABLE IF EXISTS test_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:54:05.601916 [ 3838 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 14. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 15. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:54:06.162987 [ 3097 ] {} test_3.rmt1 (518d3cd7-921f-4f7d-9866-10349a9e76df): Detached 0 parts covered by broken part all_0_0_0: 2025.06.13 15:54:06.348114 [ 3097 ] {} test_3.rmt1 (518d3cd7-921f-4f7d-9866-10349a9e76df): Detached 0 parts covered by broken part all_0_0_0_1: 2025.06.13 15:54:07.696117 [ 45511 ] {667b2357-b666-4cef-b77d-17c03ab0ed2d} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56208) (comment: 01300_svg.sql) (query 10, line 11) (in query: CREATE TABLE geo (p Tuple(Float64, Float64), s String, id Int) engine=Memory();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:07.716981 [ 45511 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:08.656119 [ 6219 ] {687684f4-cbc8-461e-877c-27009d6157d1} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56262) (comment: 00753_distributed_system_columns_and_system_tables.sql) (query 2, line 4) (in query: CREATE TABLE check_system_tables_null (key Int) Engine=Null();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:08.668525 [ 6219 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:10.795698 [ 45013 ] {4375c904-675d-4e5c-a25f-c387d0db6a08} executeQuery: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of recursive_cte AS (SELECT materialize(toUInt8(1)) AS n UNION ALL SELECT materialize(toUInt8(n + 1)) FROM recursive_cte WHERE n < 10). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56162) (comment: 03033_recursive_cte_basic.sql) (query 16, line 40) (in query: WITH RECURSIVE recursive_cte AS (SELECT materialize(toUInt8(1)) AS n UNION ALL SELECT materialize(toUInt8(n + 1)) FROM recursive_cte WHERE n < 10) SELECT n FROM recursive_cte FORMAT Null SETTINGS max_recursive_cte_evaluation_depth = 5;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6b68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x000000003223064a 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003222bece 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x000000003222bc62 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:54:10.828171 [ 18615 ] {ae9eade5-9278-478d-b325-d4f1ae41077c} 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.20286.altinityantalya (altinity build)) (from [::1]:60932) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf4487 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213d4c9 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:54:10.868139 [ 45013 ] {} TCPHandler: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of recursive_cte AS (SELECT materialize(toUInt8(1)) AS n UNION ALL SELECT materialize(toUInt8(n + 1)) FROM recursive_cte WHERE n < 10). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000001ad6b68f 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x000000003223064a 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000003222bece 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x000000003222bc62 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:54:10.879974 [ 18615 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1283: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long) @ 0x000000002ddf4487 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:744: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&) @ 0x000000003213d4c9 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:246: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&) @ 0x0000000032290786 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000032280bea 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000032164a90 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:174: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321640ce 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 15. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 16. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:54:12.341673 [ 46648 ] {a6edc804-bb86-45c2-ba48-45f0a80dd79d} executeQuery: Code: 427. DB::Exception: Invalid regexp '[]': missing ]: []. (CANNOT_COMPILE_REGEXP) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56350) (comment: 03227_json_invalid_regexp.sql) (query 2, line 2) (in query: create table test (json JSON(SKIP REGEXP '[]')) engine=Memory();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/DataTypes/DataTypeObject.cpp:76: DB::DataTypeObject::DataTypeObject(DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long, unsigned long) @ 0x000000002c44f480 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DataTypeObject* std::construct_at[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, DB::DataTypeObject*>(DB::DataTypeObject*, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c45c921 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, std::allocator, 0>(std::allocator, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c45c6f3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, 0>(std::allocator const&, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c45c50a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createJSON(std::shared_ptr const&) @ 0x000000002c45750c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5a8f5 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5b379 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5e45a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:54:12.363756 [ 46648 ] {} TCPHandler: Code: 427. DB::Exception: Invalid regexp '[]': missing ]: []. (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/DataTypes/DataTypeObject.cpp:76: DB::DataTypeObject::DataTypeObject(DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long, unsigned long) @ 0x000000002c44f480 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DataTypeObject* std::construct_at[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, DB::DataTypeObject*>(DB::DataTypeObject*, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c45c921 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, std::allocator, 0>(std::allocator, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c45c6f3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, 0>(std::allocator const&, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c45c50a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createJSON(std::shared_ptr const&) @ 0x000000002c45750c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5a8f5 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5b379 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5e45a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:54:12.498258 [ 46648 ] {26deb6db-1932-4e29-9956-60055704baaa} executeQuery: Code: 427. DB::Exception: Invalid regexp '+': no argument for repetition operator: +. (CANNOT_COMPILE_REGEXP) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56350) (comment: 03227_json_invalid_regexp.sql) (query 3, line 3) (in query: create table test (json JSON(SKIP REGEXP '+')) engine=Memory();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/DataTypes/DataTypeObject.cpp:76: DB::DataTypeObject::DataTypeObject(DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long, unsigned long) @ 0x000000002c44f480 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DataTypeObject* std::construct_at[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, DB::DataTypeObject*>(DB::DataTypeObject*, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c45c921 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, std::allocator, 0>(std::allocator, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c45c6f3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, 0>(std::allocator const&, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c45c50a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createJSON(std::shared_ptr const&) @ 0x000000002c45750c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5a8f5 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5b379 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5e45a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:54:12.510452 [ 46648 ] {} TCPHandler: Code: 427. DB::Exception: Invalid regexp '+': no argument for repetition operator: +. (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/DataTypes/DataTypeObject.cpp:76: DB::DataTypeObject::DataTypeObject(DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long, unsigned long) @ 0x000000002c44f480 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DataTypeObject* std::construct_at[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, DB::DataTypeObject*>(DB::DataTypeObject*, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c45c921 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, std::allocator, 0>(std::allocator, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c45c6f3 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>, std::unordered_set, std::equal_to, std::allocator>, std::vector>, unsigned long&, unsigned long&, 0>(std::allocator const&, DB::DataTypeObject::SchemaFormat const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&&, std::unordered_set, std::equal_to, std::allocator>&&, std::vector>&&, unsigned long&, unsigned long&) @ 0x000000002c45c50a 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createJSON(std::shared_ptr const&) @ 0x000000002c45750c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c41d400 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5a8f5 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002dc5b379 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002dc5e45a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc71627 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:54:12.855498 [ 8099 ] {28725cdd-264c-46c0-9dc1-01972d5b3ee2} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:56316) (comment: 03252_merge_tree_min_bytes_to_seek.sql) (query 3, line 7) (in query: CREATE TABLE t_min_bytes_to_seek (`id` UInt64) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 128, index_granularity_bytes = '1M', min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 434059808, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 11496810, merge_max_block_size = 3454, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 41, min_merge_bytes_to_use_direct_io = 7026750605, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 25, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 33658, primary_key_compress_block_size = 56226, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:12.869560 [ 8099 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:17.125736 [ 5112 ] {9048e2da-0040-40aa-b18d-0c3418aa10d2} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52008) (comment: 00763_long_lock_buffer_alter_destination_table.sh) (query 1, line 1) (in query: CREATE TABLE buffer_00763_1 (s String) ENGINE = Buffer(test_5, mt_00763_1, 1, 1, 1, 1, 1, 1, 1)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:17.146646 [ 5112 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:17.696141 [ 18510 ] {a097c2ba-9ee7-49d3-9e5d-f6ae93c3f2fd} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 386, line 129) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:17.726554 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:18.269143 [ 18510 ] {b256f503-6a77-4f89-8d78-2dbe7bd85fc9} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 389, line 130) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:18.279712 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:20.258081 [ 18510 ] {0040e19d-222c-45cf-99a3-1a9aeb0bff34} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 395, line 132) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:20.279329 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:20.601937 [ 45581 ] {6cc4a4e3-6e58-4f92-a3bf-d58adb481550} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52054) (comment: 02811_invalid_embedded_rocksdb_create.sql) (query 1, line 2) (in query: CREATE TABLE dict (`k` String, `v` String) ENGINE = EmbeddedRocksDB(k) PRIMARY KEY k;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:20.624645 [ 45581 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:21.799562 [ 18602 ] {ed9ee0bb-aef9-40f9-8313-23a224225390} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52126) (comment: 03223_analyzer_with_cube_fuzz.sql) (query 4, line 6) (in query: CREATE TABLE t1 (`a` Int64, `b` Int64) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 11663, 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 = 232270698, compact_parts_max_bytes_to_buffer = 74554114, compact_parts_max_granules_to_buffer = 108, compact_parts_merge_max_bytes_to_prefetch_part = 31213263, merge_max_block_size = 6573, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 298088, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 588311918, index_granularity_bytes = 19572602, 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 = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 99094, primary_key_compress_block_size = 13308, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:21.891152 [ 18602 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:22.029680 [ 45581 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:22.964282 [ 6236 ] {960460ec-e176-47a3-ab82-b20ee28a516b} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:52168) (comment: 02810_fix_remove_dedundant_distinct_view.sql) (query 3, line 3) (in query: CREATE TABLE tab (`x` UInt64, `y` UInt64) ENGINE = MergeTree ORDER BY (x, y) SETTINGS index_granularity = 25579, min_bytes_for_wide_part = 898031264, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 126706785, compact_parts_max_granules_to_buffer = 176, compact_parts_merge_max_bytes_to_prefetch_part = 33294645, merge_max_block_size = 12664, old_parts_lifetime = 132., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 2264187457, index_granularity_bytes = 6658027, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 78, 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 = 81119, primary_key_compress_block_size = 84617, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:23.005065 [ 6236 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:23.034255 [ 18510 ] {f1eacbaf-ddac-441b-b7e8-6026ef7de458} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 404, line 135) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:23.065652 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:25.028143 [ 3895 ] {fc5bd4f0-464c-4c0f-80a5-c3235faf478f} executeQuery: Code: 63. DB::Exception: Aggregate function with name 'abs' does not exist. In scope SELECT number, abs(number) OVER (PARTITION BY toString(intDiv(number, 3)) ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM numbers(10). (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45170) (comment: 01591_window_functions.sql) (query 8, line 19) (in query: -- not a window function select number, abs(number) over (partition by toString(intDiv(number, 3)) rows unbounded preceding) from numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x0000000028d845cf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3270: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3469b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:54:25.079088 [ 3895 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function with name 'abs' does not exist. In scope SELECT number, abs(number) OVER (PARTITION BY toString(intDiv(number, 3)) ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM numbers(10). (UNKNOWN_AGGREGATE_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x0000000028d845cf 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3270: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc3469b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:54:26.894825 [ 18510 ] {61dea53e-27ad-4035-a35f-b96908851943} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 416, line 139) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:26.902806 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:31.599827 [ 18510 ] {60b2f17e-0edb-4a9b-814d-7fbb691c5ef9} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 431, line 144) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:31.667457 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:33.162595 [ 45084 ] {8a1257f3-00c7-4a84-867e-7654f2d45e03} executeQuery: Code: 57. DB::Exception: Table test_3.t0 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45348) (comment: 03262_udf_in_constraint.sh) (query 2, line 3) (in query: CREATE TABLE t0 (c0 Int, CONSTRAINT c1 CHECK test_3_function(c0)) ENGINE = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:33.204064 [ 45084 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.t0 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:33.920402 [ 45085 ] {06943e67-1c8e-463d-b50d-1a8bf4db91ce} executeQuery: Code: 395. DB::Exception: Expected argument of data type real: while executing 'FUNCTION throwIf(1_Bool :: 1, 'Expected argument of data type real'_String :: 2) -> throwIf(1_Bool, 'Expected argument of data type real'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45336) (comment: 02366_kql_func_math.sql) (query 6, line 6) (in query: print isnan(4);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createRuntime(int, String const&) @ 0x0000000020a7f1ff 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c0b0 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:54:33.953546 [ 45085 ] {} TCPHandler: Code: 395. DB::Exception: Expected argument of data type real: while executing 'FUNCTION throwIf(1_Bool :: 1, 'Expected argument of data type real'_String :: 2) -> throwIf(1_Bool, 'Expected argument of data type real'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createRuntime(int, String const&) @ 0x0000000020a7f1ff 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c0b0 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:54:34.389318 [ 45085 ] {f5933a09-cfa8-455b-8555-0a9031c1b5ab} executeQuery: Code: 395. DB::Exception: Expected argument of data type real: while executing 'FUNCTION if(_CAST(0_UInt8, 'UInt8'_String) :: 1, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String) :: 2, throwIf(1_Bool, 'Expected argument of data type real'_String) :: 5) -> if(_CAST(0_UInt8, 'UInt8'_String), _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String), throwIf(1_Bool, 'Expected argument of data type real'_String)) Nullable(UInt8) : 4'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45336) (comment: 02366_kql_func_math.sql) (query 8, line 8) (in query: print isnan(dynamic(null));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createRuntime(int, String const&) @ 0x0000000020a7f1ff 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c0b0 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 10. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x000000002fc4980d 11. ./build_docker/./src/Columns/MaskOperations.cpp:299: DB::executeColumnIfNeeded(DB::ColumnWithTypeAndName&, bool) @ 0x00000000302a6499 12. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002cd40534 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 20. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 21. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 26. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:54:34.409682 [ 45085 ] {} TCPHandler: Code: 395. DB::Exception: Expected argument of data type real: while executing 'FUNCTION if(_CAST(0_UInt8, 'UInt8'_String) :: 1, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String) :: 2, throwIf(1_Bool, 'Expected argument of data type real'_String) :: 5) -> if(_CAST(0_UInt8, 'UInt8'_String), _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String), throwIf(1_Bool, 'Expected argument of data type real'_String)) Nullable(UInt8) : 4'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createRuntime(int, String const&) @ 0x0000000020a7f1ff 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c0b0 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 10. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x000000002fc4980d 11. ./build_docker/./src/Columns/MaskOperations.cpp:299: DB::executeColumnIfNeeded(DB::ColumnWithTypeAndName&, bool) @ 0x00000000302a6499 12. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002cd40534 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 20. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 21. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 26. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:54:39.639678 [ 4171 ] {1319e671-81ed-47e0-8b74-ac8c27e703f5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:57920) (comment: 03101_analyzer_identifiers_1.sql) (in query: DROP DATABASE IF EXISTS test_i7dxddmh SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:54:39.644477 [ 4171 ] {1319e671-81ed-47e0-8b74-ac8c27e703f5} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:44.793048 [ 2993 ] {} test_3.wrong_metadata (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:54:44.794726 [ 2962 ] {} test_ars9ud17.t_lightweight_mut_6 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:54:44.796848 [ 3225 ] {} test_3.replicated_truncate2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:54:44.802353 [ 2922 ] {} test_3.replicated_numbers (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:54:44.809432 [ 3039 ] {} test_13.replicated_mutations_empty_partitions (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:54:44.811280 [ 2907 ] {} test_13.enum_alter_issue (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:54:44.825806 [ 2923 ] {} test_13.sample_table_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:54:44.832899 [ 2886 ] {} test_1.wrong_metadata (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:54:44.834909 [ 2929 ] {} test_1.wrong_metadata_compact (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:54:44.837269 [ 3301 ] {} test_13.`02784_async_table_with_dedup` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:54:44.843391 [ 2947 ] {} test_3.mt_compact (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:54:44.846882 [ 3009 ] {} test_13.tp_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:54:44.852858 [ 2949 ] {} test_3.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:54:44.856165 [ 2997 ] {} test_3.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:54:44.866159 [ 42500 ] {} DatabaseCatalog: Cannot drop table test_kgrqeo7s_02911_keeper_map.`02911_backup_restore_keeper_map3` (42253efe-c37f-44bb-b28a-562f00ca12a1). Will retry later.: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test_keeper_map/test_kgrqeo7s/test02911_different/data/7gMAAAAAAAA=. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001af98c7c 5. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001af984d0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755b6f 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:347: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003275556c 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:322: zkutil::ZooKeeper::removeChildrenRecursive(String const&, zkutil::RemoveException) @ 0x000000003275d892 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:882: zkutil::ZooKeeper::removeChildrenRecursive(String const&, zkutil::RemoveException) @ 0x000000003275dd9d 10. ./build_docker/./src/Storages/StorageKeeperMap.cpp:716: DB::StorageKeeperMap::dropTable(std::shared_ptr, std::shared_ptr const&) @ 0x0000000030495010 11. ./build_docker/./src/Storages/StorageKeeperMap.cpp:804: DB::StorageKeeperMap::drop() @ 0x000000003049751a 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d5f99b1 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d607d44 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 15. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:44.866300 [ 40478 ] {} DatabaseCatalog: Cannot drop table test_kgrqeo7s_02911_keeper_map.`02911_backup_restore_keeper_map2` (7aab4640-be94-4f43-a4d9-0e7640e43bcd). Will retry later.: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test_keeper_map/test_kgrqeo7s/test02911/data/7wsAAAAAAAA=. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001af98c7c 5. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001af984d0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755b6f 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:347: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003275556c 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:322: zkutil::ZooKeeper::removeChildrenRecursive(String const&, zkutil::RemoveException) @ 0x000000003275d892 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:882: zkutil::ZooKeeper::removeChildrenRecursive(String const&, zkutil::RemoveException) @ 0x000000003275dd9d 10. ./build_docker/./src/Storages/StorageKeeperMap.cpp:716: DB::StorageKeeperMap::dropTable(std::shared_ptr, std::shared_ptr const&) @ 0x0000000030495010 11. ./build_docker/./src/Storages/StorageKeeperMap.cpp:804: DB::StorageKeeperMap::drop() @ 0x000000003049751a 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x000000002d5f99b1 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002d607d44 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000287ba974 15. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000287ba75b 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:44.901234 [ 3041 ] {} test_ars9ud17.t_lightweight_mut_6 (4f76945b-cafd-4788-8453-c560f841304a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_ars9ud17/t_lightweight_mut_6/replicas/1/log_pointer. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001af98c7c 5. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001af984d0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003275aa8f 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000003275a624 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003275a4ff 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:640: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000031102da4 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000030634b35 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:44.910077 [ 3066 ] {} test_13.`02784_async_table_with_dedup` (3d2de3f0-f5c2-45ca-97b2-6660d2e4b34c): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:44.922029 [ 2933 ] {} test_ars9ud17.t_lightweight_mut_6 (4f76945b-cafd-4788-8453-c560f841304a): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1557: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003282155a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x00000000327551ba 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032754c35 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755ab4 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755955 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000311094bd 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000003063565e 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:44.933110 [ 2983 ] {} test_ars9ud17.t_lightweight_mut_6 (4f76945b-cafd-4788-8453-c560f841304a): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1499: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000003281d28b 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1240: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000003275a18d 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:605: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x0000000032759bd6 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:626: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003275a9b3 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000003275a624 11. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003275a4ff 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:640: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x0000000031102da4 13. ./build_docker/./src/Storages/MergeTree/Compaction/MergePredicates/ReplicatedMergeTreeMergePredicate.cpp:74: DB::ReplicatedMergeTreeZooKeeperMergePredicate::ReplicatedMergeTreeZooKeeperMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>) @ 0x000000003123b728 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ReplicatedMergeTreeZooKeeperMergePredicate* std::construct_at[abi:ne190107]&, std::optional, std::equal_to, std::allocator>>, DB::ReplicatedMergeTreeZooKeeperMergePredicate*>(DB::ReplicatedMergeTreeZooKeeperMergePredicate*, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003113a872 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::optional, std::equal_to, std::allocator>>, std::allocator, 0>(std::allocator, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003113a4df 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>, 0>(std::allocator const&, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003113a346 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003112293a 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4159: DB::StorageReplicatedMergeTree::mergeSelectingTask()::$_0::operator()() const @ 0x000000003063b277 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4192: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x0000000030637d6f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 21. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 22. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:45.005970 [ 2980 ] {} test_ars9ud17.t_lightweight_mut_6 (4f76945b-cafd-4788-8453-c560f841304a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ars9ud17/t_lightweight_mut_6/replicas/1), cannot finalize mutations. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4233: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003063dcab 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 7. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:45.084884 [ 4171 ] {0728c06b-e6d1-4784-95c2-1730cec9c0ad} executeQuery: Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36130) (comment: 03047_on_fly_update_delete.sql) (query 12, line 27) (in query: ALTER TABLE t_lightweight_mut_6 DELETE WHERE id % 3 = 0;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x0000000031173f2d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x0000000031173e22 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1781: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000003281b9e0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1294: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281aad2 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1643: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x00000000328232e6 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1448: zkutil::ZooKeeper::asyncTryMultiNoThrow(std::span const, 18446744073709551615ul>) @ 0x00000000327675b2 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1435: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x00000000327577ef 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:816: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000003275c202 11. ./build_docker/./src/Storages/MergeTree/EphemeralLockInZooKeeper.cpp:181: DB::EphemeralLocksInAllPartitions::EphemeralLocksInAllPartitions(String const&, String const&, String const&, zkutil::ZooKeeper&) @ 0x0000000030b2f4c1 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6410: DB::StorageReplicatedMergeTree::allocateBlockNumbersInAffectedPartitions(DB::MutationCommands const&, std::shared_ptr, std::shared_ptr const&) const @ 0x000000003067bb47 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7908: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000306b87e8 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:54:45.139640 [ 4171 ] {} TCPHandler: Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x0000000031173f2d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x0000000031173e22 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1781: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000003281b9e0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1294: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281aad2 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1643: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x00000000328232e6 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1448: zkutil::ZooKeeper::asyncTryMultiNoThrow(std::span const, 18446744073709551615ul>) @ 0x00000000327675b2 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1435: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x00000000327577ef 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:816: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000003275c202 11. ./build_docker/./src/Storages/MergeTree/EphemeralLockInZooKeeper.cpp:181: DB::EphemeralLocksInAllPartitions::EphemeralLocksInAllPartitions(String const&, String const&, String const&, zkutil::ZooKeeper&) @ 0x0000000030b2f4c1 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6410: DB::StorageReplicatedMergeTree::allocateBlockNumbersInAffectedPartitions(DB::MutationCommands const&, std::shared_ptr, std::shared_ptr const&) const @ 0x000000003067bb47 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7908: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x00000000306b87e8 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41776 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 18. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 19. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 24. ? @ 0x00007f2f4224dac3 25. ? @ 0x00007f2f422df850 2025.06.13 15:54:45.677859 [ 46451 ] {e3177ba2-a397-4254-a0e8-f5106fb673d6} executeQuery: Code: 43. DB::Exception: Illegal types Array(UInt8) and String of arguments of function divide: In scope SELECT [1] / 'a'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36056) (comment: 02883_array_scalar_mult_div_modulo.sql) (query 25, line 25) (in query: SELECT [1] / 'a';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a5e95cb 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a06cd11 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:54:45.691451 [ 46451 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Array(UInt8) and String of arguments of function divide: In scope SELECT [1] / 'a'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001a5e95cb 6. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a06cd11 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d8734 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002aceaf2b 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb9de 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:54:45.763479 [ 45013 ] {97691ba3-881c-41bd-b0e8-f8d9a9d0b374} 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.20286.altinityantalya (altinity build)) (from [::1]:34842) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:54:45.773298 [ 45013 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:54:45.908963 [ 45013 ] {5f70c1fd-5ec9-471c-b2c7-3c73967ee0bd} 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.20286.altinityantalya (altinity build)) (from [::1]:34842) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:54:45.919050 [ 45013 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:54:45.989008 [ 45013 ] {dfa73ecb-7ebb-4f63-b5d2-873401dd9416} 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.20286.altinityantalya (altinity build)) (from [::1]:34842) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:54:45.997410 [ 45013 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:54:46.072445 [ 45013 ] {7797530a-0204-448d-aa26-711077f64a49} 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.20286.altinityantalya (altinity build)) (from [::1]:34842) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:54:46.093195 [ 45013 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:54:46.172530 [ 45013 ] {52d6d081-b336-40a9-a54a-5097cf7b76e9} 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.20286.altinityantalya (altinity build)) (from [::1]:34842) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:54:46.266065 [ 45013 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:54:46.360490 [ 45013 ] {109c9564-bb92-4b0a-9b43-d220c1535021} 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.20286.altinityantalya (altinity build)) (from [::1]:34842) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:54:46.396421 [ 45013 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000293f374f 5. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002aceaa8f 6. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002aceb92c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3543: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc302e0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 22. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 23. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 28. ? @ 0x00007f2f4224dac3 29. ? @ 0x00007f2f422df850 2025.06.13 15:54:47.124949 [ 18510 ] {545936ff-8113-4a90-b84c-1138a6bb2523} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 443, line 148) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:47.132287 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:47.432202 [ 45013 ] {5fd96829-1717-4894-90ba-1894d1d1529b} executeQuery: Code: 117. DB::Exception: Failed to base64Decode input 'Zm9vYmF=Zm9v': In scope SELECT base64Decode('Zm9vYmF=Zm9v'). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34842) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x0000000018f47f0f 5. DB::Base64Decode<(DB::Base64Variant)0>::perform(std::basic_string_view>, char8_t*) @ 0x0000000018f47e5c 6. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x0000000018f479cc 7. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f46d3b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:54:47.438604 [ 45013 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x0000000018f47f0f 5. DB::Base64Decode<(DB::Base64Variant)0>::perform(std::basic_string_view>, char8_t*) @ 0x0000000018f47e5c 6. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x0000000018f479cc 7. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f46d3b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:54:47.630117 [ 45013 ] {ad3928e8-ab1f-42e0-afbd-771b1f2ebcc6} executeQuery: Code: 117. DB::Exception: Failed to base64Decode input 'foo': In scope SELECT base64Decode('foo'). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34842) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x0000000018f47f0f 5. DB::Base64Decode<(DB::Base64Variant)0>::perform(std::basic_string_view>, char8_t*) @ 0x0000000018f47e5c 6. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x0000000018f479cc 7. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f46d3b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:54:47.648350 [ 45013 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x0000000018f47f0f 5. DB::Base64Decode<(DB::Base64Variant)0>::perform(std::basic_string_view>, char8_t*) @ 0x0000000018f47e5c 6. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x0000000018f479cc 7. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f46d3b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:54:47.865842 [ 45013 ] {7de4710d-000b-46cd-9a03-b0aa9287d34e} executeQuery: Code: 117. DB::Exception: Failed to base64Decode input 'aoeo054640eu=': In scope SELECT base64Decode('aoeo054640eu='). (INCORRECT_DATA) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34842) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x0000000018f47f0f 5. DB::Base64Decode<(DB::Base64Variant)0>::perform(std::basic_string_view>, char8_t*) @ 0x0000000018f47e5c 6. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x0000000018f479cc 7. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f46d3b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:54:47.871978 [ 45013 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x0000000018f47f0f 5. DB::Base64Decode<(DB::Base64Variant)0>::perform(std::basic_string_view>, char8_t*) @ 0x0000000018f47e5c 6. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x0000000018f479cc 7. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018f46d3b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 30. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 31. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 2025.06.13 15:54:48.476224 [ 45511 ] {8bd252bf-3ec0-4d81-8062-4034157d35c8} executeQuery: Code: 422. DB::Exception: Unsupported scheme in URI '/': The data format cannot be detected by the contents of the files. You can specify the format manually. (UNSUPPORTED_URI_SCHEME) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01030_storage_url_syntax.sql) (in query: /* ddl_entry=query-0000000002 */ CREATE TABLE test_zrrod0n3.test_table_url_syntax UUID '61825fb1-2203-47a9-ba24-2329bb0bafa6' (`id` UInt32) ENGINE = URL('')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Common/HTTPConnectionPool.cpp:900: DB::HTTPConnectionPools::Impl::useSecureConnection(Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000023f4241a 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:918: DB::HTTPConnectionPools::Impl::getPoolImpl(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000023f3ecb7 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:834: DB::HTTPConnectionPools::Impl::getPool(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000023f3d891 8. ./build_docker/./src/IO/HTTPCommon.cpp:62: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000023f6c35e 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510d28 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 15. DB::ReadBuffer::next() @ 0x0000000017e74832 16. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 18. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::StorageURLSource::getFirstAvailableURIAndReadBuffer(std::__wrap_iter&, std::__wrap_iter const&, std::shared_ptr, std::vector, std::allocator>> const&, String const&, std::function>&)>, DB::ConnectionTimeouts const&, Poco::Net::HTTPBasicCredentials&, std::vector> const&, bool, bool) @ 0x00000000307e9ef5 19. ./build_docker/./src/Storages/StorageURL.cpp:858: DB::(anonymous namespace)::ReadBufferIterator::next() @ 0x00000000307f88a1 20. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317bbcfc 21. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:556: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1b8e 22. ./build_docker/./src/Storages/StorageURL.cpp:1022: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x00000000307ed0cf 23. ./build_docker/./src/Storages/StorageURL.cpp:1043: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307e4b0c 24. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f35a2 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003080a147 26. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, std::allocator, 0>(std::allocator, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809ec7 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809cbb 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308007f2 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 2025.06.13 15:54:48.505090 [ 45511 ] {8bd252bf-3ec0-4d81-8062-4034157d35c8} executeQuery: Code: 422. DB::Exception: Unsupported scheme in URI '/': The data format cannot be detected by the contents of the files. You can specify the format manually. (UNSUPPORTED_URI_SCHEME) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34910) (comment: 01030_storage_url_syntax.sql) (query 2, line 6) (in query: create table test_table_url_syntax (id UInt32) ENGINE = URL('') ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Common/HTTPConnectionPool.cpp:900: DB::HTTPConnectionPools::Impl::useSecureConnection(Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000023f4241a 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:918: DB::HTTPConnectionPools::Impl::getPoolImpl(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000023f3ecb7 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:834: DB::HTTPConnectionPools::Impl::getPool(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000023f3d891 8. ./build_docker/./src/IO/HTTPCommon.cpp:62: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000023f6c35e 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510d28 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 15. DB::ReadBuffer::next() @ 0x0000000017e74832 16. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 18. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::StorageURLSource::getFirstAvailableURIAndReadBuffer(std::__wrap_iter&, std::__wrap_iter const&, std::shared_ptr, std::vector, std::allocator>> const&, String const&, std::function>&)>, DB::ConnectionTimeouts const&, Poco::Net::HTTPBasicCredentials&, std::vector> const&, bool, bool) @ 0x00000000307e9ef5 19. ./build_docker/./src/Storages/StorageURL.cpp:858: DB::(anonymous namespace)::ReadBufferIterator::next() @ 0x00000000307f88a1 20. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317bbcfc 21. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:556: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1b8e 22. ./build_docker/./src/Storages/StorageURL.cpp:1022: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x00000000307ed0cf 23. ./build_docker/./src/Storages/StorageURL.cpp:1043: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307e4b0c 24. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f35a2 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003080a147 26. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, std::allocator, 0>(std::allocator, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809ec7 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809cbb 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308007f2 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 2025.06.13 15:54:48.513299 [ 45511 ] {} TCPHandler: Code: 422. DB::Exception: Unsupported scheme in URI '/': The data format cannot be detected by the contents of the files. You can specify the format manually. (UNSUPPORTED_URI_SCHEME), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Common/HTTPConnectionPool.cpp:900: DB::HTTPConnectionPools::Impl::useSecureConnection(Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000023f4241a 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:918: DB::HTTPConnectionPools::Impl::getPoolImpl(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000023f3ecb7 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:834: DB::HTTPConnectionPools::Impl::getPool(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000023f3d891 8. ./build_docker/./src/IO/HTTPCommon.cpp:62: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000023f6c35e 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000028510d28 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000028511404 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000285122a7 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000028516d77 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002850d5dc 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000028514729 15. DB::ReadBuffer::next() @ 0x0000000017e74832 16. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000285102d2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000285012b2 18. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::StorageURLSource::getFirstAvailableURIAndReadBuffer(std::__wrap_iter&, std::__wrap_iter const&, std::shared_ptr, std::vector, std::allocator>> const&, String const&, std::function>&)>, DB::ConnectionTimeouts const&, Poco::Net::HTTPBasicCredentials&, std::vector> const&, bool, bool) @ 0x00000000307e9ef5 19. ./build_docker/./src/Storages/StorageURL.cpp:858: DB::(anonymous namespace)::ReadBufferIterator::next() @ 0x00000000307f88a1 20. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317bbcfc 21. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:556: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1b8e 22. ./build_docker/./src/Storages/StorageURL.cpp:1022: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x00000000307ed0cf 23. ./build_docker/./src/Storages/StorageURL.cpp:1043: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307e4b0c 24. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f35a2 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003080a147 26. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, std::allocator, 0>(std::allocator, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809ec7 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809cbb 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308007f2 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 2025.06.13 15:54:48.937299 [ 45511 ] {40f363a7-821a-4496-879b-15eedbf2d9d8} executeQuery: Code: 42. DB::Exception: Storage URL requires 1-4 arguments: url, name of used format (taken from file extension by default), optional compression method, optional headers (specified as `headers('name'='value', 'name2'='value2')`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01030_storage_url_syntax.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_zrrod0n3.test_table_url_syntax UUID '262d8807-c9fb-4547-a241-0ecf41f253b1' (`id` UInt32) ENGINE = URL('', '', '', '')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageURL.cpp:1598: DB::StorageURL::getConfiguration(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000307f7be6 6. ./build_docker/./src/Storages/StorageURL.cpp:1627: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000030800547 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:54:48.973663 [ 45511 ] {40f363a7-821a-4496-879b-15eedbf2d9d8} executeQuery: Code: 42. DB::Exception: Storage URL requires 1-4 arguments: url, name of used format (taken from file extension by default), optional compression method, optional headers (specified as `headers('name'='value', 'name2'='value2')`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34910) (comment: 01030_storage_url_syntax.sql) (query 3, line 8) (in query: create table test_table_url_syntax (id UInt32) ENGINE = URL('','','','') ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageURL.cpp:1598: DB::StorageURL::getConfiguration(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000307f7be6 6. ./build_docker/./src/Storages/StorageURL.cpp:1627: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000030800547 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:54:48.981119 [ 45511 ] {} TCPHandler: Code: 42. DB::Exception: Storage URL requires 1-4 arguments: url, name of used format (taken from file extension by default), optional compression method, optional headers (specified as `headers('name'='value', 'name2'='value2')`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Storages/StorageURL.cpp:1598: DB::StorageURL::getConfiguration(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000307f7be6 6. ./build_docker/./src/Storages/StorageURL.cpp:1627: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000030800547 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:54:49.270470 [ 2860 ] {089788b3-2de1-48a3-8657-2ff3757333f2} executeQuery: Code: 36. DB::Exception: index_granularity: value 0 makes no sense. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34932) (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 = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 506785007, compact_parts_max_granules_to_buffer = 80, compact_parts_merge_max_bytes_to_prefetch_part = 32963433, merge_max_block_size = 12675, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 57, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 8868361, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 67, 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 = 99299, primary_key_compress_block_size = 85771, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c81c0f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:526: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x0000000030f99744 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:493: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f61c 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:54:49.278357 [ 2860 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000018c81c0f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:526: DB::MergeTreeSettingsImpl::sanityCheck(unsigned long, bool, bool) const @ 0x0000000030f99744 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:493: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x0000000030c6f61c 7. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x00000000311c4f63 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, std::allocator, 0>(std::allocator, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c47db 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x00000000311c456f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x00000000311bd9d4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 17. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 18. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 23. ? @ 0x00007f2f4224dac3 24. ? @ 0x00007f2f422df850 2025.06.13 15:54:52.542729 [ 3895 ] {9a357c7a-2f4b-4e7b-a511-24baf4220da4} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45170) (comment: 01591_window_functions.sql) (query 63, line 342) (in query: CREATE TABLE window_mt ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 18455, min_bytes_for_wide_part = 691008924, ratio_of_defaults_for_sparse_serialization = 0.3445897400379181, 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 = 170530956, compact_parts_max_granules_to_buffer = 198, compact_parts_merge_max_bytes_to_prefetch_part = 31772619, merge_max_block_size = 14554, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 23505672, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 98, 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 = 82164, primary_key_compress_block_size = 20241, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true AS SELECT number, mod(number, 3) AS p FROM numbers(100)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:52.552260 [ 3895 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:52.621849 [ 18510 ] {ab73e04d-72fb-4152-931a-64cd013b3608} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 458, line 153) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:52.654343 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:53.601452 [ 46648 ] {22ec9cc2-9605-4081-9a4d-20e72fb8c0d8} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35060) (comment: 01413_allow_non_metadata_alters.sql) (query 2, line 3) (in query: CREATE TABLE non_metadata_alters ( key UInt64, value1 String, value2 Enum8('Hello' = 1, 'World' = 2), value3 UInt16, value4 DateTime, value5 Date ) ENGINE = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:53.614027 [ 46648 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:54:54.149387 [ 18615 ] {27cb5105-d2f0-4b23-ad42-2d4b6c128224} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=936, jobs=871). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35050) (comment: 01311_comparison_with_constant_string.sql) (query 6, line 6) (in query: SELECT '---';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:54.167046 [ 18615 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=936, jobs=871). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:55.440426 [ 4163 ] {8a9e8901-4f38-4381-86a8-16f73d1f19d9} executeQuery: Code: 57. DB::Exception: Table test_3.test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59852) (comment: 03141_wildcard_grants_on_tables.sh) (query 2, line 2) (in query: CREATE TABLE test_3.test_table (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 62549, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 118, min_bytes_for_full_part_storage = 504773601, compact_parts_max_bytes_to_buffer = 348669961, compact_parts_max_granules_to_buffer = 219, compact_parts_merge_max_bytes_to_prefetch_part = 33414670, merge_max_block_size = 17251, old_parts_lifetime = 136., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 3, min_merge_bytes_to_use_direct_io = 7020884767, index_granularity_bytes = 7194720, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 84142, primary_key_compress_block_size = 88630, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:55.481947 [ 4163 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:54:56.283192 [ 2860 ] {b5ac6e27-2e5e-44a3-b48b-26381e301e77} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35034) (comment: 01412_group_array_moving_shard.sql) (query 11, line 17) (in query: SELECT groupArrayMovingSum(0)(1) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027cc67e4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:54:56.290187 [ 2860 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027cc67e4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:54:56.540911 [ 45013 ] {a96ec25f-4043-4567-9f14-bea6531a966e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37870) (comment: 03352_distinct_sorted_bug.sql) (in query: DROP DATABASE IF EXISTS test_qqhki1xf SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:54:56.550381 [ 45013 ] {a96ec25f-4043-4567-9f14-bea6531a966e} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:56.572969 [ 2860 ] {77b14c19-b797-4475-af0a-19a0a78b63a7} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35034) (comment: 01412_group_array_moving_shard.sql) (query 12, line 18) (in query: SELECT groupArrayMovingSum(0.)(1) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:268: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027cc7749 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:54:56.581917 [ 2860 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:268: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027cc7749 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:54:56.652596 [ 2860 ] {fbd5d58e-5650-46b9-99b6-b7a2adcde44c} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35034) (comment: 01412_group_array_moving_shard.sql) (query 13, line 19) (in query: SELECT groupArrayMovingSum(0.1)(1) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:268: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027cc7749 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:54:56.675590 [ 2860 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:268: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027cc7749 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:54:56.716068 [ 18615 ] {96b3aab4-f3c5-444c-bb30-87c638195a01} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37882) (comment: 03352_distinct_sorted_bug.sql) (in query: DROP DATABASE IF EXISTS test_qqhki1xf SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:54:56.728038 [ 18615 ] {96b3aab4-f3c5-444c-bb30-87c638195a01} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:56.857916 [ 2860 ] {534fd0aa-b108-4f73-a57a-7e8989194247} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35034) (comment: 01412_group_array_moving_shard.sql) (query 14, line 20) (in query: SELECT groupArrayMovingSum(0.1)(1) FROM remote('127.0.0.{1,2}', numbers(100));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:268: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027cc7749 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:54:56.879204 [ 2860 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:268: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000027cc7749 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b3c42b5 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002b3c26a7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3367: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc313ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:54:58.260832 [ 4163 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:54:59.746741 [ 2860 ] {8c517281-2c92-458f-aac6-6be756ab4a0a} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: 10000000000 is not in range (-2147483648, 2147483647): In scope SELECT groupArrayMovingSum(256)(toDecimal32(1000000000, 1)) FROM numbers(300). (DECIMAL_OVERFLOW) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35034) (comment: 01412_group_array_moving_shard.sql) (query 19, line 25) (in query: SELECT groupArrayMovingSum(256)(toDecimal32(1000000000, 1)) FROM numbers(300);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002c49737c 6. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002c4b0907 7. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002b23d579 8. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b232f00 9. ./src/Core/callOnTypeIndex.h:254: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02eaa5 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b06a09e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b068f03 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 2025.06.13 15:54:59.761744 [ 2860 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: 10000000000 is not in range (-2147483648, 2147483647): In scope SELECT groupArrayMovingSum(256)(toDecimal32(1000000000, 1)) FROM numbers(300). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000017e0a8cf 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002c49737c 6. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002c4b0907 7. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002b23d579 8. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002b232f00 9. ./src/Core/callOnTypeIndex.h:254: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002b02eaa5 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b06a09e 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002b068f03 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 2025.06.13 15:54:59.843594 [ 7755 ] {a2826d8a-75ac-40c7-abe4-41e448b804a5} PushingToViews: Failed to push block to view test_3.mv (cc153e5e-ccb0-4d07-b5ea-3d469e360e3a), Unknown expression identifier `x` in scope SELECT x, CAST([(y, z)], 'Nested(y int, z int)') FROM test_3.t. Maybe you meant: ['i'] 2025.06.13 15:55:00.096300 [ 7755 ] {a2826d8a-75ac-40c7-abe4-41e448b804a5} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x, CAST([(y, z)], 'Nested(y int, z int)') FROM test_3.t. Maybe you meant: ['i']. (UNKNOWN_IDENTIFIER) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59928) (comment: 02112_delayed_clickhouse_client_with_queries_file.expect) (query 3, line 1) (in query: insert into t select 'test string' ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd64522 15. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000031ef056b 16. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031ef4e24 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dcdd134 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dcdf787 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dce12f7 20. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5edc 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:55:00.107687 [ 7755 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x, CAST([(y, z)], 'Nested(y int, z int)') FROM test_3.t. Maybe you meant: ['i']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x000000002cc5aff7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3770: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc068d5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd64522 15. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x0000000031ef056b 16. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x0000000031ef4e24 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002dcdd134 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000002dcdf787 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002dce12f7 20. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5edc 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 23. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 24. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 29. ? @ 0x00007f2f4224dac3 30. ? @ 0x00007f2f422df850 2025.06.13 15:55:00.207602 [ 45485 ] {8bc9938e-6ed0-48be-83d3-423bfe98664a} executeQuery: Code: 36. DB::Exception: Argument 'format/NOSIGN' must be a literal with type String, got Array. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59910) (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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./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>&&) @ 0x000000003084508f 5. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:39: String DB::checkAndGetLiteralArgument(DB::ASTLiteral const&, String const&) @ 0x0000000030843f87 6. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:22: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000030843ae4 7. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:279: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x000000002b62deed 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:616: DB::StorageObjectStorage::Configuration::initialize(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool, std::shared_ptr) @ 0x000000002b527b4a 9. ./src/TableFunctions/TableFunctionObjectStorage.h:137: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000285450ae 10. ./build_docker/./src/TableFunctions/TableFunctionObjectStorage.cpp:105: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000028547372 11. ./src/TableFunctions/ITableFunctionCluster.h:59: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000285c15d7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:00.232127 [ 45485 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./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>&&) @ 0x000000003084508f 5. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:39: String DB::checkAndGetLiteralArgument(DB::ASTLiteral const&, String const&) @ 0x0000000030843f87 6. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:22: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000030843ae4 7. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:279: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x000000002b62deed 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:616: DB::StorageObjectStorage::Configuration::initialize(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool, std::shared_ptr) @ 0x000000002b527b4a 9. ./src/TableFunctions/TableFunctionObjectStorage.h:137: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000285450ae 10. ./build_docker/./src/TableFunctions/TableFunctionObjectStorage.cpp:105: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000028547372 11. ./src/TableFunctions/ITableFunctionCluster.h:59: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000285c15d7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4828: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002cc08e64 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5324: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x000000002cc4fc0d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5582: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a48 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:01.991152 [ 18510 ] {d04fb96d-ec79-466d-befe-88877d0f2956} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 488, line 163) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:02.013460 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:02.464746 [ 45485 ] {0d02e254-0d81-4fa2-b0e0-25263915c438} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:37944) (comment: 02870_move_partition_to_volume_io_throttling.sql) (in query: DROP DATABASE IF EXISTS test_jp5yifc4 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:55:02.472560 [ 45485 ] {0d02e254-0d81-4fa2-b0e0-25263915c438} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:04.803159 [ 8431 ] {0d041ad2-5d63-4e09-9a06-0ebfdbc16b2d} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:59836) (comment: 01946_profile_sleep.sql) (query 15, line 45) (in query: CREATE VIEW sleep_view AS SELECT sleepEachRow(0.001) FROM system.numbers;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:04.819983 [ 8431 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:05.676078 [ 45485 ] {7f90f853-c8a9-44aa-b6f0-7ab69de6a17c} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50118) (comment: 02001_join_on_const.sql) (query 3, line 4) (in query: CREATE TABLE t1 (id Int) ENGINE = TinyLog;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:05.689597 [ 45485 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:06.127773 [ 18615 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:06.821068 [ 18510 ] {c9f7c972-7a07-4884-ac09-e90d1df3c6e8} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 503, line 168) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:06.828093 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:08.322149 [ 45485 ] {5b8acf12-7450-46e2-933e-64c019bb7ec3} executeQuery: Code: 57. DB::Exception: Table test_2awg6mdw.t_with_dots already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50156) (comment: 02017_columns_with_dot.sql) (query 6, line 9) (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 index_granularity = 30092, min_bytes_for_wide_part = 1067712159, 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 = 148568995, compact_parts_max_granules_to_buffer = 223, compact_parts_merge_max_bytes_to_prefetch_part = 27947957, merge_max_block_size = 7035, old_parts_lifetime = 189., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 2, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 22109175, 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 = false, marks_compress_block_size = 62845, primary_key_compress_block_size = 57845, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:08.336302 [ 45485 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2awg6mdw.t_with_dots already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:09.972972 [ 5112 ] {c7635b0d-49af-470a-8732-5f34e6a1e39b} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50174) (comment: 02560_vertical_merge_memory_usage.sql) (query 2, line 3) (in query: CREATE TABLE tvm (`c0` UInt64, `c1` UInt64, `c2` UInt64, `c3` UInt64, `c4` UInt64, `c5` UInt64, `c6` UInt64, `c7` UInt64, `c8` UInt64, `c9` UInt64, `c10` UInt64, `c11` UInt64, `c12` UInt64, `c13` UInt64, `c14` UInt64, `c15` UInt64, `c16` UInt64, `c17` UInt64, `c18` UInt64, `c19` UInt64, `c20` UInt64, `c21` UInt64, `c22` UInt64, `c23` UInt64, `c24` UInt64, `c25` UInt64, `c26` UInt64, `c27` UInt64, `c28` UInt64, `c29` UInt64, `c30` UInt64, `c31` UInt64, `c32` UInt64, `c33` UInt64, `c34` UInt64, `c35` UInt64, `c36` UInt64, `c37` UInt64, `c38` UInt64, `c39` UInt64, `c40` UInt64, `c41` UInt64, `c42` UInt64, `c43` UInt64, `c44` UInt64, `c45` UInt64, `c46` UInt64, `c47` UInt64, `c48` UInt64, `c49` UInt64, `c50` UInt64, `c51` UInt64, `c52` UInt64, `c53` UInt64, `c54` UInt64, `c55` UInt64, `c56` UInt64, `c57` UInt64, `c58` UInt64, `c59` UInt64, `c60` UInt64, `c61` UInt64, `c62` UInt64, `c63` UInt64, `c64` UInt64, `c65` UInt64, `c66` UInt64, `c67` UInt64, `c68` UInt64, `c69` UInt64, `c70` UInt64, `c71` UInt64, `c72` UInt64, `c73` UInt64, `c74` UInt64, `c75` UInt64, `c76` UInt64, `c77` UInt64, `c78` UInt64, `c79` UInt64, `c80` UInt64, `c81` UInt64, `c82` UInt64, `c83` UInt64, `c84` UInt64, `c85` UInt64, `c86` UInt64, `c87` UInt64, `c88` UInt64, `c89` UInt64, `c90` UInt64, `c91` UInt64, `c92` UInt64, `c93` UInt64, `c94` UInt64, `c95` UInt64, `c96` UInt64, `c97` UInt64, `c98` UInt64, `c99` UInt64, `c100` UInt64, `c101` UInt64, `c102` UInt64, `c103` UInt64, `c104` UInt64, `c105` UInt64, `c106` UInt64, `c107` UInt64, `c108` UInt64, `c109` UInt64, `c110` UInt64, `c111` UInt64, `c112` UInt64, `c113` UInt64, `c114` UInt64, `c115` UInt64, `c116` UInt64, `c117` UInt64, `c118` UInt64, `c119` UInt64, `c120` UInt64, `c121` UInt64, `c122` UInt64, `c123` UInt64, `c124` UInt64, `c125` UInt64, `c126` UInt64, `c127` UInt64, `c128` UInt64, `c129` UInt64, `c130` UInt64, `c131` UInt64, `c132` UInt64, `c133` UInt64, `c134` UInt64, `c135` UInt64, `c136` UInt64, `c137` UInt64, `c138` UInt64, `c139` UInt64, `c140` UInt64, `c141` UInt64, `c142` UInt64, `c143` UInt64, `c144` UInt64, `c145` UInt64, `c146` UInt64, `c147` UInt64, `c148` UInt64, `c149` UInt64, `c150` UInt64, `c151` UInt64, `c152` UInt64, `c153` UInt64, `c154` UInt64, `c155` UInt64, `c156` UInt64, `c157` UInt64, `c158` UInt64, `c159` UInt64, `c160` UInt64, `c161` UInt64, `c162` UInt64, `c163` UInt64, `c164` UInt64, `c165` UInt64, `c166` UInt64, `c167` UInt64, `c168` UInt64, `c169` UInt64, `c170` UInt64, `c171` UInt64, `c172` UInt64, `c173` UInt64, `c174` UInt64, `c175` UInt64, `c176` UInt64, `c177` UInt64, `c178` UInt64, `c179` UInt64, `c180` UInt64, `c181` UInt64, `c182` UInt64, `c183` UInt64, `c184` UInt64, `c185` UInt64, `c186` UInt64, `c187` UInt64, `c188` UInt64, `c189` UInt64, `c190` UInt64, `c191` UInt64, `c192` UInt64, `c193` UInt64, `c194` UInt64, `c195` UInt64, `c196` UInt64, `c197` UInt64, `c198` UInt64, `c199` UInt64, `c200` UInt64, `c201` UInt64, `c202` UInt64, `c203` UInt64, `c204` UInt64, `c205` UInt64, `c206` UInt64, `c207` UInt64, `c208` UInt64, `c209` UInt64, `c210` UInt64, `c211` UInt64, `c212` UInt64, `c213` UInt64, `c214` UInt64, `c215` UInt64, `c216` UInt64, `c217` UInt64, `c218` UInt64, `c219` UInt64, `c220` UInt64, `c221` UInt64, `c222` UInt64, `c223` UInt64, `c224` UInt64, `c225` UInt64, `c226` UInt64, `c227` UInt64, `c228` UInt64, `c229` UInt64, `c230` UInt64, `c231` UInt64, `c232` UInt64, `c233` UInt64, `c234` UInt64, `c235` UInt64, `c236` UInt64, `c237` UInt64, `c238` UInt64, `c239` UInt64, `c240` UInt64, `c241` UInt64, `c242` UInt64, `c243` UInt64, `c244` UInt64, `c245` UInt64, `c246` UInt64, `c247` UInt64, `c248` UInt64, `c249` UInt64, `c250` UInt64, `c251` UInt64, `c252` UInt64, `c253` UInt64, `c254` UInt64, `c255` UInt64, `c256` UInt64, `c257` UInt64, `c258` UInt64, `c259` UInt64, `c260` UInt64, `c261` UInt64, `c262` UInt64, `c263` UInt64, `c264` UInt64, `c265` UInt64, `c266` UInt64, `c267` UInt64, `c268` UInt64, `c269` UInt64, `c270` UInt64, `c271` UInt64, `c272` UInt64, `c273` UInt64, `c274` UInt64, `c275` UInt64, `c276` UInt64, `c277` UInt64, `c278` UInt64, `c279` UInt64, `c280` UInt64, `c281` UInt64, `c282` UInt64, `c283` UInt64, `c284` UInt64, `c285` UInt64, `c286` UInt64, `c287` UInt64, `c288` UInt64, `c289` UInt64, `c290` UInt64, `c291` UInt64, `c292` UInt64, `c293` UInt64, `c294` UInt64, `c295` UInt64, `c296` UInt64, `c297` UInt64, `c298` UInt64, `c299` UInt64) ENGINE = MergeTree ORDER BY tuple() SETTINGS min_rows_for_wide_part = 10, min_bytes_for_wide_part = 0, vertical_merge_algorithm_min_rows_to_activate = 1, index_granularity = 78, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 85, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 5753062, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 28543887, merge_max_block_size = 20188, old_parts_lifetime = 460., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26050710, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 29111, primary_key_compress_block_size = 91400, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:09.994976 [ 5112 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:10.711594 [ 5112 ] {b2b2483a-acf6-4a8f-b641-9b191a6b8df8} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50194) (comment: 02902_select_subcolumns_from_engine_null.sql) (query 1, line 1) (in query: CREATE TABLE null_02902 (t Tuple(num Int64, str String)) ENGINE = Null;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:10.723501 [ 5112 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:11.022359 [ 18510 ] {d4a0f89f-4f6c-4e47-a726-ed70e538c875} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 521, line 174) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:11.041240 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:11.550328 [ 45683 ] {cd23a7f5-e913-4743-9f1b-dcdded48f7d4} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50088) (comment: 02864_statistics_predicates.sql) (query 22, line 90) (in query: SELECT count(*) FROM tab WHERE u64 = '7.7';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:11.618142 [ 45683 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:11.677851 [ 45683 ] {31b8fa63-fd2c-437a-bfb7-033f27f33eb4} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50088) (comment: 02864_statistics_predicates.sql) (query 23, line 91) (in query: SELECT count(*) FROM tab WHERE u64_tdigest = '7.7';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:11.710700 [ 45683 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:11.828935 [ 45683 ] {855d69c9-acef-4958-bd44-f8c321e448e7} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50088) (comment: 02864_statistics_predicates.sql) (query 24, line 92) (in query: SELECT count(*) FROM tab WHERE u64_minmax = '7.7';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:11.847562 [ 45683 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:11.920252 [ 5112 ] {753fabab-3d9d-49a0-93ba-e4a484aba2a2} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50210) (comment: 03132_sqlancer_union_all.sql) (query 7, line 9) (in query: CREATE TABLE t0 (c0 String) ENGINE = Memory() ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:11.956777 [ 5112 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:12.020404 [ 45683 ] {9a8fd6c7-497a-4580-8bde-a1c43d28661a} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50088) (comment: 02864_statistics_predicates.sql) (query 25, line 93) (in query: SELECT count(*) FROM tab WHERE u64_countmin = '7.7';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:12.032044 [ 45683 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:12.168949 [ 45683 ] {1972e566-5173-4396-bdf1-49ec92dc2ad6} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50088) (comment: 02864_statistics_predicates.sql) (query 26, line 94) (in query: SELECT count(*) FROM tab WHERE u64_uniq = '7.7';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:12.180024 [ 45683 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6fde68 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2217 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:13.002570 [ 5112 ] {c51ad835-ff1e-4304-9c5d-a4cb3329cfbb} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50230) (comment: 02235_check_table_sparse_serialization.sql) (query 2, line 3) (in query: CREATE TABLE t_sparse_02235 (`a` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS ratio_of_defaults_for_sparse_serialization = 0.9, index_granularity = 19063, min_bytes_for_wide_part = 105013832, replace_long_file_name_to_hash = false, max_file_name_length = 82, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 387865211, compact_parts_max_granules_to_buffer = 186, compact_parts_merge_max_bytes_to_prefetch_part = 4411034, merge_max_block_size = 11020, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1322967427, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4534700245, index_granularity_bytes = 2462107, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, 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 = false, marks_compress_block_size = 68290, primary_key_compress_block_size = 51849, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:13.019459 [ 5112 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:14.073504 [ 5112 ] {e720a73a-3182-4f3a-91ec-bb5cbfd7454b} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55538) (comment: 03146_create_index_compatibility.sql) (query 2, line 3) (in query: CREATE TABLE t_index_3146 (a UInt64, b UInt64) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:14.089503 [ 5112 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:15.031719 [ 3009 ] {} test_3.wrong_metadata (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:55:15.034265 [ 3142 ] {} test_3.replicated_truncate2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:55:15.038909 [ 3171 ] {} test_3.replicated_numbers (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:55:15.050237 [ 3153 ] {} test_13.replicated_mutations_empty_partitions (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:55:15.051426 [ 2900 ] {} test_13.enum_alter_issue (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:55:15.054026 [ 3144 ] {} test_13.sample_table_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:55:15.064110 [ 2963 ] {} test_1.wrong_metadata (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:55:15.072817 [ 3237 ] {} test_1.wrong_metadata_compact (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:55:15.085407 [ 3177 ] {} test_13.`02784_async_table_with_dedup` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:55:15.104032 [ 2914 ] {} test_3.mt_compact (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:55:15.110873 [ 3179 ] {} test_13.tp_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:55:15.123936 [ 3158 ] {} test_3.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:55:15.128898 [ 3082 ] {} test_3.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 15:55:16.230538 [ 5112 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:18.050487 [ 18510 ] {9ce50ba2-87c1-4f6f-a025-4cb1ede9f0da} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 548, line 183) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:18.084561 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:18.305302 [ 45683 ] {5d6123be-2c24-4543-8705-a8494d7de9c7} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50088) (comment: 02864_statistics_predicates.sql) (query 43, line 116) (in query: SELECT count(*) FROM tab WHERE u64 < '7.7';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0cfd28 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b40d7 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:18.318664 [ 45683 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0cfd28 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b40d7 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:18.433261 [ 45683 ] {eb292d38-39c1-478b-9b20-254ac500e932} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50088) (comment: 02864_statistics_predicates.sql) (query 44, line 117) (in query: SELECT count(*) FROM tab WHERE u64_tdigest < '7.7';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0cfd28 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b40d7 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:18.448891 [ 45683 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0cfd28 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b40d7 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:18.593778 [ 45683 ] {abbe22ea-65d5-469f-b5ea-756dad86767e} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50088) (comment: 02864_statistics_predicates.sql) (query 45, line 118) (in query: SELECT count(*) FROM tab WHERE u64_minmax < '7.7';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0cfd28 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b40d7 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:18.598936 [ 45683 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0cfd28 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b40d7 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:18.688321 [ 45683 ] {dfd826fb-4f4a-4f94-a5c4-a627a6a4e5e1} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50088) (comment: 02864_statistics_predicates.sql) (query 46, line 119) (in query: SELECT count(*) FROM tab WHERE u64_countmin < '7.7';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0cfd28 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b40d7 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:18.694162 [ 45683 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0cfd28 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b40d7 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:18.820864 [ 45683 ] {bae5c2ad-29b5-46a7-a902-85397bc3f859} executeQuery: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50088) (comment: 02864_statistics_predicates.sql) (query 47, line 120) (in query: SELECT count(*) FROM tab WHERE u64_uniq < '7.7';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0cfd28 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b40d7 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:18.836856 [ 45683 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '7.7' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000001874c76f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e25862a 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000002e253e0d 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0cfd28 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001d0b40d7 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 16. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 17. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 19. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 20. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 21. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 25. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 26. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 31. ? @ 0x00007f2f4224dac3 2025.06.13 15:55:20.139129 [ 18510 ] {db70bee1-2671-43fa-ac3c-1bd55342e17e} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 557, line 186) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:20.228523 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:22.668223 [ 45511 ] {8da84706-44d9-4b53-84b4-07743e325a60} executeQuery: Code: 715. DB::Exception: The data format cannot be detected by the contents of the files: Poco::Exception. Code: 1000, e.code() = 111, Connection refused (version 25.3.3.20286.altinityantalya (altinity build)). You can specify the format manually. (CANNOT_DETECT_FORMAT) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01030_storage_url_syntax.sql) (in query: /* ddl_entry=query-0000000004 */ CREATE TABLE test_zrrod0n3.test_table_url UUID '1a917534-e61e-4214-a2f1-73bf341acc13' (`id` UInt32) ENGINE = URL('http://localhost/endpoint')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:209: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1521 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:556: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1b8e 7. ./build_docker/./src/Storages/StorageURL.cpp:1022: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x00000000307ed0cf 8. ./build_docker/./src/Storages/StorageURL.cpp:1043: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307e4b0c 9. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f35a2 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003080a147 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, std::allocator, 0>(std::allocator, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809ec7 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809cbb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308007f2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 20. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 21. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 22. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 23. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:55:22.676665 [ 45511 ] {8da84706-44d9-4b53-84b4-07743e325a60} executeQuery: Code: 715. DB::Exception: The data format cannot be detected by the contents of the files: Poco::Exception. Code: 1000, e.code() = 111, Connection refused (version 25.3.3.20286.altinityantalya (altinity build)). You can specify the format manually. (CANNOT_DETECT_FORMAT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34910) (comment: 01030_storage_url_syntax.sql) (query 6, line 16) (in query: create table test_table_url(id UInt32) ENGINE = URL('http://localhost/endpoint') ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:209: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1521 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:556: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1b8e 7. ./build_docker/./src/Storages/StorageURL.cpp:1022: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x00000000307ed0cf 8. ./build_docker/./src/Storages/StorageURL.cpp:1043: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307e4b0c 9. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f35a2 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003080a147 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, std::allocator, 0>(std::allocator, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809ec7 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809cbb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308007f2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 20. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 21. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 22. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 23. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:55:22.699953 [ 45511 ] {} TCPHandler: Code: 715. DB::Exception: The data format cannot be detected by the contents of the files: Poco::Exception. Code: 1000, e.code() = 111, Connection refused (version 25.3.3.20286.altinityantalya (altinity build)). You can specify the format manually. (CANNOT_DETECT_FORMAT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:209: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1521 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:556: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000317c1b8e 7. ./build_docker/./src/Storages/StorageURL.cpp:1022: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x00000000307ed0cf 8. ./build_docker/./src/Storages/StorageURL.cpp:1043: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307e4b0c 9. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f35a2 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003080a147 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, std::allocator, 0>(std::allocator, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809ec7 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809cbb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308007f2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 20. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 21. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 22. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 23. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:55:22.948473 [ 45124 ] {0e5a5bbb-691c-414d-b8ed-0dc497d25133} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:55680). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:22.965557 [ 45124 ] {0e5a5bbb-691c-414d-b8ed-0dc497d25133} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:55680). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55680) (query 1, line 1) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:22.988917 [ 45124 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:55680). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.037645 [ 34302 ] {a6100a1e-ae1d-4987-ad3f-1d7eccaf1963} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55714). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:23.038351 [ 45736 ] {7172ffb1-3aad-4e8b-b914-701b018caf1a} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55666). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:23.085821 [ 34302 ] {a6100a1e-ae1d-4987-ad3f-1d7eccaf1963} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55714). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55714) (query 1, line 1) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.099645 [ 34302 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55714). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.146369 [ 46651 ] {2f348ef0-f4ce-46d1-8772-15a68b82e5b8} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55702) (query 1, line 1) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316d8600 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316cc924 5. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e5d 6. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.148538 [ 45736 ] {7172ffb1-3aad-4e8b-b914-701b018caf1a} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55666). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55666) (query 1, line 1) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.173056 [ 46651 ] {2f348ef0-f4ce-46d1-8772-15a68b82e5b8} 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]:55702). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2619: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000316ba300 7. ./build_docker/./src/Server/TCPHandler.cpp:820: DB::TCPHandler::runImpl() @ 0x00000000316a4b63 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:23.199474 [ 46651 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316d8600 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316cc924 5. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e5d 6. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.210871 [ 6236 ] {c1aeaaef-bd49-4f3d-aa86-604adc9ea24f} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55736). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:23.209105 [ 45736 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55666). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.244072 [ 6236 ] {c1aeaaef-bd49-4f3d-aa86-604adc9ea24f} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55736). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55736) (query 1, line 1) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.258074 [ 6236 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55736). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.276438 [ 18510 ] {07e8ca58-c08b-4c94-887c-e8fb9e0e2069} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 569, line 190) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.285159 [ 45085 ] {0937b513-9f88-4c81-a37b-83ec5d7a509f} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:55750). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:23.306804 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.311446 [ 45085 ] {0937b513-9f88-4c81-a37b-83ec5d7a509f} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:55750). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55750) (query 1, line 1) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.316798 [ 5163 ] {d1196536-cbd4-4b0a-b59e-f677b5785f5b} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55794). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:23.329527 [ 45085 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:55750). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.357879 [ 5163 ] {d1196536-cbd4-4b0a-b59e-f677b5785f5b} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55794). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55794) (query 1, line 1) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.374243 [ 5163 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55794). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.400939 [ 46451 ] {b26347e9-3ce5-40c2-9e32-807e3903f083} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55772) (query 1, line 1) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316d8600 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316cc924 5. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e5d 6. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.447903 [ 46451 ] {b26347e9-3ce5-40c2-9e32-807e3903f083} 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]:55772). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:825: DB::TCPHandler::runImpl() @ 0x00000000316a4c07 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:23.507747 [ 8430 ] {ba51d823-a68f-4667-93cb-9f2a1d421ea4} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55796). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:23.516070 [ 46451 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x00000000316d8600 4. ./build_docker/./src/Server/TCPHandler.cpp:2425: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000316cc924 5. ./build_docker/./src/Server/TCPHandler.cpp:1241: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e5d 6. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.552430 [ 8430 ] {ba51d823-a68f-4667-93cb-9f2a1d421ea4} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55796). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55796) (query 1, line 1) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.600215 [ 8430 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:55796). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.700205 [ 6219 ] {4c860b32-53a8-4fc7-9b73-5ebabbe3cb54} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:45282). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:23.737318 [ 6219 ] {4c860b32-53a8-4fc7-9b73-5ebabbe3cb54} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:45282). (NETWORK_ERROR) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45282) (query 1, line 1) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:23.770669 [ 6219 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:45282). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf931 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:2489: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000316ca463 7. ./build_docker/./src/Server/TCPHandler.cpp:1265: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b9052 8. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 9. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 2025.06.13 15:55:25.085144 [ 45511 ] {4e0b4a4c-f67f-4366-9e13-e2175249c8bc} executeQuery: Code: 73. DB::Exception: Unknown format ErrorFormat. (UNKNOWN_FORMAT) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01030_storage_url_syntax.sql) (in query: /* ddl_entry=query-0000000007 */ CREATE TABLE test_zrrod0n3.test_table_url UUID 'b10cf958-fe79-4318-8adb-0bafbddf8aaf' (`id` UInt32) ENGINE = URL('http://localhost/endpoint', 'ErrorFormat')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Formats/FormatFactory.cpp:937: DB::FormatFactory::checkFormatName(String const&) const @ 0x0000000031734e6a 6. ./build_docker/./src/Storages/StorageURL.cpp:168: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307e485e 7. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f35a2 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003080a147 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, std::allocator, 0>(std::allocator, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809ec7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809cbb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308007f2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:55:25.148774 [ 45511 ] {4e0b4a4c-f67f-4366-9e13-e2175249c8bc} executeQuery: Code: 73. DB::Exception: Unknown format ErrorFormat. (UNKNOWN_FORMAT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34910) (comment: 01030_storage_url_syntax.sql) (query 9, line 22) (in query: create table test_table_url(id UInt32) ENGINE = URL('http://localhost/endpoint', 'ErrorFormat') ;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Formats/FormatFactory.cpp:937: DB::FormatFactory::checkFormatName(String const&) const @ 0x0000000031734e6a 6. ./build_docker/./src/Storages/StorageURL.cpp:168: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307e485e 7. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f35a2 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003080a147 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, std::allocator, 0>(std::allocator, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809ec7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809cbb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308007f2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:55:25.160249 [ 45511 ] {} TCPHandler: Code: 73. DB::Exception: Unknown format ErrorFormat. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Formats/FormatFactory.cpp:937: DB::FormatFactory::checkFormatName(String const&) const @ 0x0000000031734e6a 6. ./build_docker/./src/Storages/StorageURL.cpp:168: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307e485e 7. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x00000000307f35a2 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000003080a147 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, std::allocator, 0>(std::allocator, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809ec7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000030809cbb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000308007f2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000303c9b5f 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1938: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc7d9c8 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 20. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 21. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 26. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 27. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 2025.06.13 15:55:26.251472 [ 45511 ] {814acfbb-2973-4676-902f-3386c8f83e57} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage URL. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01030_storage_url_syntax.sql) (in query: /* ddl_entry=query-0000000009 */ TRUNCATE TABLE test_zrrod0n3.test_table_url), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:55:26.264032 [ 34370 ] {fbf68536-4215-4815-9f35-373e14744a6e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:44744) (comment: 02036_jit_short_circuit.sql) (in query: DROP DATABASE IF EXISTS test_u261in59 SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:55:26.281898 [ 34370 ] {fbf68536-4215-4815-9f35-373e14744a6e} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:26.406879 [ 45511 ] {814acfbb-2973-4676-902f-3386c8f83e57} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage URL. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:34910) (comment: 01030_storage_url_syntax.sql) (query 11, line 26) (in query: drop table test_table_url;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:55:26.426465 [ 45511 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage URL. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000030312118 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0362 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca7076 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:55:27.223708 [ 18510 ] {e38acc1c-5138-44c6-9217-375544d01098} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 584, line 195) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:27.255277 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:28.479916 [ 46014 ] {5a0e9993-0c2e-41a0-92e1-1e487633e349} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=27, jobs=6): While reading or decompressing /var/lib/clickhouse/store/e29/e299b615-0145-447d-b7cf-170ec402d80c/all_1_1_0/value.bin (position: 1443237, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 371ff5185771830b95e0a6d6f6bf77ce821880000000000100): (while reading column value): (while reading from part /var/lib/clickhouse/store/e29/e299b615-0145-447d-b7cf-170ec402d80c/all_1_1_0/ in table test_tkwqubnm.num_2 (e299b615-0145-447d-b7cf-170ec402d80c) located on disk default of type local, from mark 36 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45348) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (query 1, line 2) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2) r on l.key = r.key order by l.key limit 10 offset 700000 SETTINGS allow_experimental_analyzer=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032da5a52 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c605763 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 2025.06.13 15:55:28.643471 [ 46014 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=27, jobs=6): While reading or decompressing /var/lib/clickhouse/store/e29/e299b615-0145-447d-b7cf-170ec402d80c/all_1_1_0/value.bin (position: 1443237, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 371ff5185771830b95e0a6d6f6bf77ce821880000000000100): (while reading column value): (while reading from part /var/lib/clickhouse/store/e29/e299b615-0145-447d-b7cf-170ec402d80c/all_1_1_0/ in table test_tkwqubnm.num_2 (e299b615-0145-447d-b7cf-170ec402d80c) located on disk default of type local, from mark 36 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032da5a52 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c605763 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:55:31.079182 [ 18510 ] {64d6bae3-1411-46d1-ac6d-7fefee542903} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 599, line 200) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:31.093752 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:32.890336 [ 34302 ] {1c0062c0-4fe2-4589-b05a-68b3ace3ef92} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45422) (comment: 00338_replicate_array_of_strings.sql) (query 2, line 4) (in query: CREATE TABLE bad_arrays (a Array(String), b Array(UInt8)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:32.912086 [ 34302 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:33.236019 [ 18509 ] {922e2c3b-2676-48d5-acfd-f64ddcc954ec} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=29, jobs=16): While reading or decompressing /var/lib/clickhouse/store/5d3/5d39185b-0dec-4cf6-99a7-dd4027e63a1c/all_5_5_0/value.bin (position: 655360, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 0377343b16967b334513eaf34e04a7b4820e82000000000100): (while reading column value): (while reading from part /var/lib/clickhouse/store/5d3/5d39185b-0dec-4cf6-99a7-dd4027e63a1c/all_5_5_0/ in table test_tkwqubnm.num_1 (5d39185b-0dec-4cf6-99a7-dd4027e63a1c) located on disk default of type local, from mark 0 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:55710) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (query 1, line 2) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value`, `__table3`.`key` AS `r.key`, `__table3`.`value` AS `r.value` FROM (SELECT `__table2`.`key` AS `key`, `__table2`.`value` AS `value` FROM `test_tkwqubnm`.`num_1` AS `__table2`) AS `__table1` GLOBAL ALL INNER JOIN `_data_8694961507948544258_10003853363081927446` AS `__table3` ON `__table1`.`key` = `__table3`.`key` ORDER BY `__table1`.`key` ASC LIMIT _CAST(700000, 'UInt64'), _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032da3168 17. DB::ReadBuffer::next() @ 0x0000000017e74832 18. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002c66dc72 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 30. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 2025.06.13 15:55:33.414498 [ 18509 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=29, jobs=16): While reading or decompressing /var/lib/clickhouse/store/5d3/5d39185b-0dec-4cf6-99a7-dd4027e63a1c/all_5_5_0/value.bin (position: 655360, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 0377343b16967b334513eaf34e04a7b4820e82000000000100): (while reading column value): (while reading from part /var/lib/clickhouse/store/5d3/5d39185b-0dec-4cf6-99a7-dd4027e63a1c/all_5_5_0/ in table test_tkwqubnm.num_1 (5d39185b-0dec-4cf6-99a7-dd4027e63a1c) located on disk default of type local, from mark 0 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032da3168 17. DB::ReadBuffer::next() @ 0x0000000017e74832 18. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002c66dc72 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 30. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181b22b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:55:33.463093 [ 46014 ] {2f72b8f0-c17e-4d17-98f0-47b9fdc47d2c} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=29, jobs=16): While reading or decompressing /var/lib/clickhouse/store/5d3/5d39185b-0dec-4cf6-99a7-dd4027e63a1c/all_5_5_0/value.bin (position: 655360, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 0377343b16967b334513eaf34e04a7b4820e82000000000100): (while reading column value): (while reading from part /var/lib/clickhouse/store/5d3/5d39185b-0dec-4cf6-99a7-dd4027e63a1c/all_5_5_0/ in table test_tkwqubnm.num_1 (5d39185b-0dec-4cf6-99a7-dd4027e63a1c) located on disk default of type local, from mark 0 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032da3168 17. DB::ReadBuffer::next() @ 0x0000000017e74832 18. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002c66dc72 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 30. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181b22b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45388) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (query 1, line 2) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2) r on l.key = r.key order by l.key limit 10 offset 700000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_prefer_local_join = 0, parallel_replicas_local_plan=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:55:33.513707 [ 46014 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=29, jobs=16): While reading or decompressing /var/lib/clickhouse/store/5d3/5d39185b-0dec-4cf6-99a7-dd4027e63a1c/all_5_5_0/value.bin (position: 655360, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 0377343b16967b334513eaf34e04a7b4820e82000000000100): (while reading column value): (while reading from part /var/lib/clickhouse/store/5d3/5d39185b-0dec-4cf6-99a7-dd4027e63a1c/all_5_5_0/ in table test_tkwqubnm.num_1 (5d39185b-0dec-4cf6-99a7-dd4027e63a1c) located on disk default of type local, from mark 0 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000032da3168 17. DB::ReadBuffer::next() @ 0x0000000017e74832 18. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002c66dc72 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000030f57cbc 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f56bc3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 27. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 30. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181b22b 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:55:33.797641 [ 4098 ] {2f135495-0653-452f-8141-1a1fb9025eda} 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]:37764). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000023cac667 4. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000023caf591 5. DB::WriteBuffer::next() @ 0x0000000017cd5383 6. ./build_docker/./src/Server/TCPHandler.cpp:823: DB::TCPHandler::runImpl() @ 0x00000000316a4ba1 7. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 12. ? @ 0x00007f2f4224dac3 13. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:34.152622 [ 34302 ] {9d923a5e-7d4e-4997-a176-7761238825ac} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36542) (comment: 00746_compile_non_deterministic_function.sql) (query 4, line 6) (in query: CREATE TABLE time_table (`timecol` DateTime, `value` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 38924, min_bytes_for_wide_part = 140478422, 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 = 252649940, compact_parts_max_bytes_to_buffer = 326944629, compact_parts_max_granules_to_buffer = 89, compact_parts_merge_max_bytes_to_prefetch_part = 6750170, merge_max_block_size = 21959, old_parts_lifetime = 390., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 17195741, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 28339, primary_key_compress_block_size = 37315, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:34.167257 [ 34302 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:35.023591 [ 2868 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5646 similar messages) 2025.06.13 15:55:35.339389 [ 34302 ] {c5a8580b-b853-4606-af46-548876a800ab} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36592) (comment: 01070_alter_with_ttl.sql) (query 3, line 5) (in query: create table alter_ttl(i Int) engine = MergeTree order by i ttl toDate('2020-05-05');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:35.379541 [ 9636 ] {4f1ca150-98de-4d2b-865a-e8af5a112713} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=29, jobs=0): While reading or decompressing /var/lib/clickhouse/store/e29/e299b615-0145-447d-b7cf-170ec402d80c/all_2_2_0/data.bin (position: 2136417, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 224014f0dbdb9df34bf30c3ad37a58e3821980000000000100): (while reading column value): (while reading from part /var/lib/clickhouse/store/e29/e299b615-0145-447d-b7cf-170ec402d80c/all_2_2_0/ in table test_tkwqubnm.num_2 (e299b615-0145-447d-b7cf-170ec402d80c) located on disk default of type local, from mark 32 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:56084) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (query 1, line 2) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value` FROM `test_tkwqubnm`.`num_2` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032da5a52 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c605763 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f29714 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f4b8d3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 2025.06.13 15:55:35.414668 [ 4172 ] {2d2cea06-b10c-4cb6-8e1c-14e44009eb59} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=29, jobs=0): While reading or decompressing /var/lib/clickhouse/store/e29/e299b615-0145-447d-b7cf-170ec402d80c/all_2_2_0/data.bin (position: 2136417, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 224014f0dbdb9df34bf30c3ad37a58e3821980000000000100): (while reading column value): (while reading from part /var/lib/clickhouse/store/e29/e299b615-0145-447d-b7cf-170ec402d80c/all_2_2_0/ in table test_tkwqubnm.num_2 (e299b615-0145-447d-b7cf-170ec402d80c) located on disk default of type local, from mark 32 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032da5a52 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c605763 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f29714 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f4b8d3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36576) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (query 1, line 2) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2) r on l.key = r.key order by l.key limit 10 offset 700000 SETTINGS enable_analyzer=1, send_logs_level='trace', enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_prefer_local_join = 0, parallel_replicas_local_plan=0), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e 2025.06.13 15:55:35.428852 [ 9636 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=29, jobs=0): While reading or decompressing /var/lib/clickhouse/store/e29/e299b615-0145-447d-b7cf-170ec402d80c/all_2_2_0/data.bin (position: 2136417, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 224014f0dbdb9df34bf30c3ad37a58e3821980000000000100): (while reading column value): (while reading from part /var/lib/clickhouse/store/e29/e299b615-0145-447d-b7cf-170ec402d80c/all_2_2_0/ in table test_tkwqubnm.num_2 (e299b615-0145-447d-b7cf-170ec402d80c) located on disk default of type local, from mark 32 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032da5a52 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c605763 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f29714 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f4b8d3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:55:35.433172 [ 34302 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:35.595898 [ 4172 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=29, jobs=0): While reading or decompressing /var/lib/clickhouse/store/e29/e299b615-0145-447d-b7cf-170ec402d80c/all_2_2_0/data.bin (position: 2136417, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 224014f0dbdb9df34bf30c3ad37a58e3821980000000000100): (while reading column value): (while reading from part /var/lib/clickhouse/store/e29/e299b615-0145-447d-b7cf-170ec402d80c/all_2_2_0/ in table test_tkwqubnm.num_2 (e299b615-0145-447d-b7cf-170ec402d80c) located on disk default of type local, from mark 32 with max_rows_to_read = 40960): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b40df59 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b40ddb7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b40c3dd 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002b3f7d84 11. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002b3f8980 12. DB::ReadBuffer::next() @ 0x0000000017e74832 13. DB::ReadBuffer::read(char*, unsigned long) @ 0x0000000017e74622 14. ./build_docker/./src/IO/ReadBuffer.cpp:47: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000023b288ce 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000032d9ebac 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000032da5a52 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002c605763 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002c528d07 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000030f29714 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f4b8d3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::readRows(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, unsigned long) @ 0x0000000030f37baf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:188: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000030f37fa1 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000030f439e5 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000030f742d5 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000030f6edd1 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x00000000321c0091 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x0000000030f7d5bf 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000032217095 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000023b34b45 4. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003147e448 5. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003148e074 6. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000315010d8 7. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002c3eae05 8. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002c3e8a2d 9. ./src/Common/Fiber.h:76: Fiber::RoutineImpl::operator()(boost::context::fiber&&) @ 0x000000002c3e86a0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: boost::context::detail::fiber_capture_record>::run() @ 0x000000002c3e8397 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002c3e689e Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 8. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:315: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x000000003083e270 9. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:391: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x00000000308382b9 10. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:497: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000002dd89f32 11. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6e43f 12. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 16. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 17. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 22. ? @ 0x00007f2f4224dac3 23. ? @ 0x00007f2f422df850 2025.06.13 15:55:36.318613 [ 45736 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:36.329531 [ 45085 ] {1fd87d26-65ee-4615-b285-a18c84c4f703} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_27nvrbto.rmt (6043024c-751b-43d8-856c-66de21da0e2a)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36646) (comment: 02253_empty_part_checksums.sh) (query 1, line 1) (in query: INSERT INTO rmt SELECT rand(1), 0, 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(1000);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:55:36.348390 [ 45085 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_27nvrbto.rmt (6043024c-751b-43d8-856c-66de21da0e2a)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x000000002dce5736 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 9. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 10. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:55:36.877694 [ 34302 ] {4ce7048f-8e95-46b6-84d7-28f882e8dd73} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36610) (comment: 02967_parallel_replicas_join_algo_and_analyzer_1.sh) (query 1, line 2) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2) r on l.key = r.key order by l.key limit 10 offset 700000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_prefer_local_join = 0, parallel_replicas_local_plan=1), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 11. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:315: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x000000003083e270 12. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:391: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x00000000308382b9 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:497: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000002dd89f32 14. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6e43f 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:55:36.914789 [ 34302 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817e40 11. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:315: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x000000003083e270 12. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:391: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x00000000308382b9 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:497: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x000000002dd89f32 14. ./build_docker/./src/Planner/Planner.cpp:1563: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6e43f 15. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:55:38.534623 [ 45736 ] {98247cdc-90d6-40e3-8406-a6a2f1aed6ca} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43506) (comment: 01268_mv_scalars.sql) (in query: DROP DATABASE IF EXISTS test_gdmeorie SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:55:38.575557 [ 45736 ] {98247cdc-90d6-40e3-8406-a6a2f1aed6ca} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:38.667439 [ 18510 ] {7a7f5c34-8528-4205-8db0-110d822b1f91} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 626, line 209) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:38.668153 [ 45084 ] {553ccad7-c78f-4031-8bad-06a970b477fe} executeQuery: Code: 395. DB::Exception: Path is relative: : while executing 'FUNCTION throwIf(_CAST(1_UInt8, 'UInt8'_String) :: 1, 'Path is relative: '_String :: 2) -> throwIf(_CAST(1_UInt8, 'UInt8'_String), 'Path is relative: '_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36730) (comment: 02253_empty_part_checksums.sh) (query 1, line 1) (in query: select throwIf(substring('', 1, 1) != '/', 'Path is relative: ')), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createRuntime(int, String const&) @ 0x0000000020a7f1ff 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c0b0 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 2025.06.13 15:55:38.688799 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:38.772888 [ 45084 ] {} TCPHandler: Code: 395. DB::Exception: Path is relative: : while executing 'FUNCTION throwIf(_CAST(1_UInt8, 'UInt8'_String) :: 1, 'Path is relative: '_String :: 2) -> throwIf(_CAST(1_UInt8, 'UInt8'_String), 'Path is relative: '_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::createRuntime(int, String const&) @ 0x0000000020a7f1ff 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000020a7c0b0 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000031dbc869 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x00000000317fe53a 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 21. ? @ 0x00007f2f4224dac3 22. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:55:39.038826 [ 45084 ] {1f02d4a0-d9f6-4cce-9f54-cb563b376bca} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_27nvrbto.rmt (6043024c-751b-43d8-856c-66de21da0e2a)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:43524) (comment: 02253_empty_part_checksums.sh) (in query: DROP DATABASE IF EXISTS test_27nvrbto SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 2025.06.13 15:55:39.045956 [ 45084 ] {1f02d4a0-d9f6-4cce-9f54-cb563b376bca} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_27nvrbto.rmt (6043024c-751b-43d8-856c-66de21da0e2a)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000017cd3d6f 5. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002dc50135 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca5849 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcabbcf 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 20. ? @ 0x00007f2f4224dac3 21. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:42.919982 [ 18510 ] {3358363d-cbc1-4a75-ad04-374473a672c9} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 638, line 213) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:42.948642 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:43.147743 [ 46451 ] {4119f264-54e4-4828-9195-9ac6351da006} executeQuery: Code: 36. DB::Exception: Last open curly brace is not closed: In scope SELECT format('{', ''). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 14, line 19) (in query: select format('{', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef66b1 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:43.176810 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Last open curly brace is not closed: In scope SELECT format('{', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef66b1 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:43.647917 [ 46451 ] {509f3874-ab5d-4430-9c6d-ae9f83b7cfdb} executeQuery: Code: 36. DB::Exception: Closed curly brace without open one at position 2: In scope SELECT format('{{}', ''). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 15, line 20) (in query: select format('{{}', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef64b5 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:43.665235 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Closed curly brace without open one at position 2: In scope SELECT format('{{}', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef64b5 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:44.181848 [ 46451 ] {1bf30127-19ab-499d-a0a0-b40d87ff0c2f} executeQuery: Code: 36. DB::Exception: Two open curly braces without close one at position 2: In scope SELECT format('{ {}', ''). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 16, line 21) (in query: select format('{ {}', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef63e2 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:44.192246 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Two open curly braces without close one at position 2: In scope SELECT format('{ {}', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef63e2 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:44.277754 [ 46451 ] {f5a8f2fb-95e4-4fb4-a487-84e6753420a9} executeQuery: Code: 36. DB::Exception: Closed curly brace without open one at position 0: In scope SELECT format('}', ''). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 17, line 22) (in query: select format('}', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef64b5 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:44.290446 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Closed curly brace without open one at position 0: In scope SELECT format('}', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef64b5 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:44.595932 [ 46451 ] {41ca21ce-8039-453f-a3ce-d58cf942caa1} executeQuery: Code: 36. DB::Exception: Last open curly brace is not closed: In scope SELECT format('{}}', ''). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 19, line 24) (in query: select format('{}}', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef66b1 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:44.605016 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Last open curly brace is not closed: In scope SELECT format('{}}', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef66b1 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:45.106074 [ 46451 ] {fdad4b69-ff6b-4f78-9ff5-5026cc7ab84e} executeQuery: Code: 36. DB::Exception: Too big number for arguments, must be at most 0: In scope SELECT format('{2 }', ''). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 21, line 26) (in query: select format('{2 }', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x0000000019d384af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef62be 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:45.117529 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Too big number for arguments, must be at most 0: In scope SELECT format('{2 }', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x0000000019d384af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef62be 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:45.274891 [ 46451 ] {5ed0031b-78c2-4832-a39a-53eee2471676} executeQuery: Code: 36. DB::Exception: Closed curly brace without open one at position 13: In scope SELECT format('{}{}{}{}{}{} }{}', '', '', '', '', '', '', ''). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 22, line 27) (in query: select format('{}{}{}{}{}{} }{}', '', '', '', '', '', '', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef64b5 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:45.283480 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Closed curly brace without open one at position 13: In scope SELECT format('{}{}{}{}{}{} }{}', '', '', '', '', '', '', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef64b5 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:45.565809 [ 46451 ] {94ff7bc6-e600-4866-9f98-a3c21d619b6a} executeQuery: Code: 36. DB::Exception: Not a number in curly braces at position 1: In scope SELECT format('{sometext}', ''). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 23, line 28) (in query: select format('{sometext}', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef6332 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:45.574158 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Not a number in curly braces at position 1: In scope SELECT format('{sometext}', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef6332 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:45.638026 [ 46451 ] {e93e2aa2-1a51-4708-9dd2-0acbcdeb3efa} executeQuery: Code: 36. DB::Exception: Not a number in curly braces at position 1: In scope SELECT format('{\0sometext}', ''). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 24, line 29) (in query: select format('{\0sometext}', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef6332 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:45.642898 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Not a number in curly braces at position 1: In scope SELECT format('{\0sometext}', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef6332 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:45.708643 [ 46451 ] {f476dab7-0325-4d7e-a673-3b4473212709} executeQuery: Code: 36. DB::Exception: Too big number for arguments, must be at most 0: In scope SELECT format('{1023}', ''). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 25, line 30) (in query: select format('{1023}', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x0000000019d384af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef62be 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:45.715765 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Too big number for arguments, must be at most 0: In scope SELECT format('{1023}', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x0000000019d384af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef62be 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:45.808598 [ 46451 ] {f2f22959-c784-427b-b7a8-56fc12a6a1a0} executeQuery: Code: 36. DB::Exception: Too big number for arguments, must be at most 0: In scope SELECT format('{10000000000000000000000000000000000000000000000000}', ''). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 26, line 31) (in query: select format('{10000000000000000000000000000000000000000000000000}', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x0000000019d384af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef62be 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:45.818838 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Too big number for arguments, must be at most 0: In scope SELECT format('{10000000000000000000000000000000000000000000000000}', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x0000000019d384af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef62be 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:45.958896 [ 46451 ] {90ba9122-2c88-4de9-9754-ef7163581c11} executeQuery: Code: 36. DB::Exception: Cannot switch from automatic field numbering to manual field specification: In scope SELECT format('{} {0}', '', ''). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 27, line 32) (in query: select format('{} {0}', '', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef67d2 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:45.975261 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Cannot switch from automatic field numbering to manual field specification: In scope SELECT format('{} {0}', '', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef67d2 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:46.139837 [ 46451 ] {6ee1772d-0076-4d5d-917f-5d986d0e7473} executeQuery: Code: 36. DB::Exception: Cannot switch from automatic field numbering to manual field specification: In scope SELECT format('{0} {}', '', ''). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 28, line 33) (in query: select format('{0} {}', '', '');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef675c 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:46.150324 [ 18510 ] {70575538-2de3-46b7-bac8-4189c4ca0520} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 2.13 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 648, line 216) (in query: INSERT INTO mt_00763_2 SELECT toString(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b684b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b683f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b67671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023cffee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c94d347 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c93f7d8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030af5e0c 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd6aa3 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dc188d 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c5a27a 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030feff3e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e43ccf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e3f751 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031229dad 24. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f67cf7 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 2025.06.13 15:55:46.171897 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Cannot switch from automatic field numbering to manual field specification: In scope SELECT format('{0} {}', '', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef675c 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:46.187362 [ 18510 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 2.13 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b684b1 11. ./build_docker/./src/IO/WriteBufferFromFileBase.cpp:7: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x0000000023b683f6 12. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x0000000023b67671 13. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x0000000023cffee2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002c94d347 15. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c93f7d8 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000030af5e0c 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd6aa3 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dc188d 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c5a27a 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030feff3e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e43ccf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e3f751 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031229dad 24. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f67cf7 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003181c6ad 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:55:46.407454 [ 46451 ] {e549d0c0-4124-4bcd-90d2-48b079fe34c6} executeQuery: Code: 36. DB::Exception: Not enough arguments to fill the placeholders in the format string: In scope SELECT format('Hello {} World {} {}{}', 'first', 'second', 'third') FROM system.numbers LIMIT 2. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 29, line 34) (in query: select format('Hello {} World {} {}{}', 'first', 'second', 'third') from system.numbers limit 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef65fe 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:46.410789 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Not enough arguments to fill the placeholders in the format string: In scope SELECT format('Hello {} World {} {}{}', 'first', 'second', 'third') FROM system.numbers LIMIT 2. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef65fe 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:46.472670 [ 46451 ] {08b5c7be-3bd5-4024-86a3-66e5b58f688f} executeQuery: Code: 36. DB::Exception: Too big number for arguments, must be at most 2: In scope SELECT format('Hello {0} World {1} {2}{3}', 'first', 'second', 'third') FROM system.numbers LIMIT 2. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 30, line 35) (in query: select format('Hello {0} World {1} {2}{3}', 'first', 'second', 'third') from system.numbers limit 2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x0000000019d384af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef62be 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:46.481422 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Too big number for arguments, must be at most 2: In scope SELECT format('Hello {0} World {1} {2}{3}', 'first', 'second', 'third') FROM system.numbers LIMIT 2. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x0000000019d384af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef62be 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 31. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 2025.06.13 15:55:46.633805 [ 46451 ] {612010e4-930e-4bff-904e-43a3396223be} executeQuery: Code: 36. DB::Exception: Last open curly brace is not closed: In scope SELECT 50 = length(format((SELECT arrayStringConcat(arrayMap(x -> '{', range(101)))), '')). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 31, line 37) (in query: select 50 = length(format((select arrayStringConcat(arrayMap(x ->'{', range(101)))), ''));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef66b1 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace68cd 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5864 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 31. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 2025.06.13 15:55:46.641241 [ 46451 ] {} TCPHandler: Code: 36. DB::Exception: Last open curly brace is not closed: In scope SELECT 50 = length(format((SELECT arrayStringConcat(arrayMap(x -> '{', range(101)))), '')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. DB::Format::init(String const&, unsigned long, std::vector, std::allocator>> const&, DB::PODArray, 64ul, 8ul>, 0ul, 0ul>&, std::vector>&) @ 0x0000000019ef66b1 6. void DB::FormatStringImpl::format(String, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>> const&, std::vector> const&, std::vector, std::allocator>> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x0000000019efe951 7. void DB::FormatStringImpl::formatExecute, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&>(bool, bool, String&&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector, 63ul, 64ul> const*, std::allocator, 63ul, 64ul> const*>>&, std::vector>&, std::vector, std::allocator>>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, unsigned long&) @ 0x0000000019efc1e3 8. DB::(anonymous namespace)::FormatFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ad8dd45 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 12. DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace68cd 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5864 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2924: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc295f6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 31. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 2025.06.13 15:55:47.083074 [ 9636 ] {77ca8110-9423-4948-b19d-a640d8b26fd2} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36624) (comment: 03165_round_scale_as_column.sql) (query 37, line 46) (in query: CREATE TABLE tab ( id Int32, scale Int16, u8 UInt8, u16 UInt16, u32 UInt32, u64 UInt64, i8 Int8, i16 Int16, i32 Int32, i64 Int64, f32 Float32, f64 Float64 ) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:47.107892 [ 9636 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:48.159938 [ 4171 ] {b553740f-db1e-4614-b30c-7649238e9d21} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51760) (comment: 02796_projection_date_filter_on_view.sql) (query 3, line 4) (in query: CREATE TABLE fx_1m (`symbol` LowCardinality(String) CODEC(ZSTD), `dt_close` DateTime64(3, 'UTC') CODEC(DoubleDelta, ZSTD), `open` Float32 CODEC(Delta, ZSTD), `high` Float32 CODEC(Delta, ZSTD), `low` Float32 CODEC(Delta, ZSTD), `close` Float32 CODEC(Delta, ZSTD), `volume` Float32 CODEC(Delta, ZSTD)) ENGINE = MergeTree PARTITION BY toYear(dt_close) ORDER BY (symbol, dt_close) SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 102, min_bytes_for_full_part_storage = 62803168, compact_parts_max_bytes_to_buffer = 501890269, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 9815486, merge_max_block_size = 12115, old_parts_lifetime = 38., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 9457946816, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 81, 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 = 61638, primary_key_compress_block_size = 50649, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:48.176495 [ 4171 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:49.408260 [ 46451 ] {f8a96fa2-8734-4dc2-b3a3-c6f3ade223c6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=936, jobs=882). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:36766) (comment: 00949_format.sql) (query 45, line 57) (in query: select format('{}{}', toFixedString('a', 1), materialize('b')) == 'ab';), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:49.442097 [ 46451 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=936, jobs=882). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc68fa 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf0c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 7. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 9. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 10. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:50.028779 [ 8430 ] {0b5b169e-9120-4b94-984a-514d3b7348ed} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_hj2z5tc1.src (0d427ba7-51e9-48e3-8d42-8392db706ed5), because some tables depend on it: test_hj2z5tc1.mv. (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51798) (comment: 02552_check_referential_table_dependencies.sql) (query 8, line 11) (in query: -- Can't drop because of referential dependencies DROP TABLE src;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d60a06f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd0c4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd596 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca75b3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:55:50.043295 [ 8430 ] {} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_hj2z5tc1.src (0d427ba7-51e9-48e3-8d42-8392db706ed5), because some tables depend on it: test_hj2z5tc1.mv. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d60a06f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd0c4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd596 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca75b3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:55:50.098391 [ 8430 ] {6ac23b28-679f-4158-8ac3-116bc470b4d4} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_hj2z5tc1.dst (1686c294-5c63-4b3b-8cf0-e8486a9f487b), because some tables depend on it: test_hj2z5tc1.mv. (HAVE_DEPENDENT_OBJECTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51798) (comment: 02552_check_referential_table_dependencies.sql) (query 9, line 13) (in query: DROP TABLE dst;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d60a06f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd0c4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd596 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca75b3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:55:50.121041 [ 8430 ] {} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_hj2z5tc1.dst (1686c294-5c63-4b3b-8cf0-e8486a9f487b), because some tables depend on it: test_hj2z5tc1.mv. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000002d60a06f 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1553: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd0c4 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1535: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x000000002d5fd596 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002dca75b3 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000002dca48fe 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3579 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 13. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 14. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:55:50.775277 [ 8430 ] {6ec386f8-0021-41e9-8683-7431f503decd} executeQuery: Code: 57. DB::Exception: Table test_hj2z5tc1.src already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51798) (comment: 02552_check_referential_table_dependencies.sql) (query 13, line 20) (in query: -- Check again with check_referential_table_dependencies = 0 CREATE TABLE src (x UInt8) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:50.797761 [ 8430 ] {} TCPHandler: Code: 57. DB::Exception: Table test_hj2z5tc1.src already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:51.570724 [ 2860 ] {11bbd268-22f0-48ec-a74b-5e20af3ebee3} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51854) (comment: 02240_protobuflist_format_persons.sh) (query 6, line 7) (in query: CREATE TABLE persons_02240 (`uuid` UUID, `name` String, `surname` String, `gender` Enum8('male' = 1, 'female' = 0), `birthDate` Date, `photo` Nullable(String), `phoneNumber` Nullable(FixedString(13)), `isOnline` UInt8, `visitTime` Nullable(DateTime('Europe/Moscow')), `age` UInt8, `zodiacSign` Enum16('aries' = 321, 'taurus' = 420, 'gemini' = 521, 'cancer' = 621, 'leo' = 723, 'virgo' = 823, 'libra' = 923, 'scorpius' = 1023, 'sagittarius' = 1122, 'capricorn' = 1222, 'aquarius' = 120, 'pisces' = 219), `songs` Array(String), `color` Array(UInt8), `hometown` LowCardinality(String), `location` Array(Decimal32(6)), `pi` Nullable(Float64), `lotteryWin` Nullable(Decimal64(2)), `someRatio` Float32, `temperature` Decimal32(1), `randomBigNumber` Int64, `measureUnits` Nested(unit String, coef Float32), `nestiness_a_b_c_d` Nullable(UInt32), `nestiness_a_B.c_E` Array(UInt32)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 35018, min_bytes_for_wide_part = 949863936, 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 = 58766843, compact_parts_max_granules_to_buffer = 46, compact_parts_merge_max_bytes_to_prefetch_part = 28461620, merge_max_block_size = 4844, old_parts_lifetime = 421., 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 = 20828124, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 47046, primary_key_compress_block_size = 50814, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:51.604041 [ 2860 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x000000002c7b71e1 6. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002c7b0208 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1137: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002c77490a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72122 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:55:52.266272 [ 3895 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:52.480444 [ 2945 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x000000002d5f8b30 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000002d5f92c1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:55:52.787357 [ 45683 ] {80b2bc9a-258a-4681-9ec6-e6c60ef875f9} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50088) (comment: 02864_statistics_predicates.sql) (query 134, line 238) (in query: SELECT count(*) FROM tab WHERE s = 7;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c510038 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c515483 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7000b6 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2bd0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 19. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 20. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:55:52.813831 [ 45683 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c510038 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c515483 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7000b6 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2bd0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 19. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 20. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:55:52.949238 [ 45683 ] {a88ea451-0b06-4963-b355-54f3768adb98} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50088) (comment: 02864_statistics_predicates.sql) (query 135, line 239) (in query: -- SELECT count(*) FROM tab WHERE s_tdigest = 7; -- not supported -- SELECT count(*) FROM tab WHERE s_minmax = 7; -- not supported SELECT count(*) FROM tab WHERE s_countmin = 7;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c510038 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c515483 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7000b6 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2bd0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 19. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 20. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:55:52.968803 [ 45683 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c510038 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c515483 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7000b6 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2bd0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 19. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 20. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:55:53.172661 [ 45683 ] {84f76e71-27e9-4098-b4fa-f72249b800a1} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:50088) (comment: 02864_statistics_predicates.sql) (query 136, line 242) (in query: SELECT count(*) FROM tab WHERE s_uniq = 7;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c510038 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c515483 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7000b6 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2bd0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 19. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 20. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:55:53.184159 [ 45683 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002c510038 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002c515483 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000001a7000b6 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6e2bd0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000002cb1818e 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002cb16cfe 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000031dc0abf 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003210d02f 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000002dd3e729 18. ./build_docker/./src/Planner/Planner.cpp:409: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002dd78b8a 19. ./build_docker/./src/Planner/Planner.cpp:1629: DB::Planner::buildPlanForQueryNode() @ 0x000000002dd6f08b 20. ./build_docker/./src/Planner/Planner.cpp:1323: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002dd686d9 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002dd65219 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2316 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 24. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 25. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 30. ? @ 0x00007f2f4224dac3 31. ? @ 0x00007f2f422df850 2025.06.13 15:55:55.467339 [ 45013 ] {4bdd140d-3bd4-41f5-a08a-e6a7f4a564f6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:51864) (comment: 02383_analyzer_merge_tree_self_join.sql) (query 14, line 31) (in query: SELECT * FROM test_table_join_1 AS t1 LEFT JOIN test_table_join_2 AS t2 ON t1.id = t2.id ORDER BY t1.id, t1.value;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc3b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000030e200de 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a5ce1 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:55:55.498511 [ 45013 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bc3b16 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:806: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000030e200de 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1805: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x00000000321a5ce1 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x00000000321a485e 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x00000000321a44ee 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1993: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x00000000321ae013 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2101: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000321b0a59 13. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002dd64fd3 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002dd64bc6 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 19. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 20. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 25. ? @ 0x00007f2f4224dac3 26. ? @ 0x00007f2f422df850 2025.06.13 15:55:56.665755 [ 18510 ] {d109d5b8-4946-4f83-8744-9a43f351a507} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 689, line 230) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:56.675507 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:57.370869 [ 45013 ] {124c4692-0d8c-4722-8806-f198855317fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 4, line 4) (in query: SELECT BLAKE3(NULL, NULL, NULL);) 2025.06.13 15:55:57.393134 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:55:57.464327 [ 45013 ] {1c1859f0-347d-4fe0-b446-e4235ba9a391} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 5, line 6) (in query: SELECT CHARACTER_LENGTH(NULL, NULL, NULL);) 2025.06.13 15:55:57.478831 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:55:57.589638 [ 45013 ] {7f27b291-4a1c-46ea-a062-69211d5a2cf7} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 6, line 7) (in query: SELECT CHAR_LENGTH(NULL, NULL, NULL);) 2025.06.13 15:55:57.602050 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:55:58.120180 [ 45013 ] {1b7fc1d0-9850-4fef-a401-2c9fb04689d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 9, line 10) (in query: SELECT CRC32(NULL, NULL, NULL);) 2025.06.13 15:55:58.128957 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:55:58.209788 [ 45013 ] {45eef35c-61ab-4b1a-b195-46c3e7b4fd98} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 10, line 11) (in query: SELECT CRC32IEEE(NULL, NULL, NULL);) 2025.06.13 15:55:58.240524 [ 4163 ] {e9906d46-8c2e-4d80-a135-92ff69bedb3f} executeQuery: Code: 53. DB::Exception: Function dictGetString dictionary attribute has different type Nullable(String) expected String: In scope SELECT dictGetString('02125_test_dictionary', 'value', toUInt64(0)). (TYPE_MISMATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42268) (comment: 02125_dict_get_type_nullable_fix.sql) (query 7, line 22) (in query: SELECT dictGetString('02125_test_dictionary', 'value', toUInt64(0));), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f7d4f2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:55:58.245023 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:55:58.255370 [ 4163 ] {} TCPHandler: Code: 53. DB::Exception: Function dictGetString dictionary attribute has different type Nullable(String) expected String: In scope SELECT dictGetString('02125_test_dictionary', 'value', toUInt64(0)). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000017e0af4f 5. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017f7d4f2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017cbd3ef 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1d0e 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace589f 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace4ff6 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5829 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3566: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc31712 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3837: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc04a60 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 28. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 29. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 2025.06.13 15:55:58.363890 [ 45013 ] {edfc92d1-a0af-431f-83ed-c33dc18cee4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 11, line 12) (in query: SELECT CRC64(NULL, NULL, NULL);) 2025.06.13 15:55:58.459543 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:55:58.520514 [ 45013 ] {f82b24ea-0648-4b9f-a1b8-20f29feefab6} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 12, line 13) (in query: SELECT DATABASE(NULL, NULL, NULL);) 2025.06.13 15:55:58.533502 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:55:59.474874 [ 18510 ] {0fc0a326-4ca1-4967-9d3e-04370c73f210} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 701, line 234) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:59.483001 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:55:59.817303 [ 45013 ] {b4eb9769-503a-4f57-aad4-c4a39ca4b87c} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 21, line 22) (in query: SELECT FORMAT_BYTES(NULL, NULL, NULL);) 2025.06.13 15:55:59.857878 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:55:59.969298 [ 45013 ] {db6fe8b3-38d2-4b93-a371-4eb3f79b4e38} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 22, line 23) (in query: SELECT FQDN(NULL, NULL, NULL);) 2025.06.13 15:55:59.989205 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:00.117500 [ 45013 ] {28f60dd5-562c-4b12-9061-07e1dfac0d04} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 23, line 24) (in query: SELECT FROM_BASE64(NULL, NULL, NULL);) 2025.06.13 15:56:00.129887 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:00.216693 [ 45013 ] {a702fe6e-14b8-4fed-9f82-7126808266ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 24, line 25) (in query: SELECT FROM_DAYS(NULL, NULL, NULL);) 2025.06.13 15:56:00.246221 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:00.597195 [ 45013 ] {6143ca1f-bbfa-49ec-aa6f-fa35820821e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 27, line 28) (in query: SELECT INET6_ATON(NULL, NULL, NULL);) 2025.06.13 15:56:00.606578 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:00.698170 [ 45013 ] {35c37e23-2662-4ee4-864e-f98936e989d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 28, line 29) (in query: SELECT INET6_NTOA(NULL, NULL, NULL);) 2025.06.13 15:56:00.711764 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:00.811120 [ 45013 ] {02cab8a2-de75-4839-b96a-9e14b227d5f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 29, line 30) (in query: SELECT INET_ATON(NULL, NULL, NULL);) 2025.06.13 15:56:00.842324 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:00.912904 [ 45013 ] {b443330d-7425-4e33-80f4-429cd64c26c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 30, line 31) (in query: SELECT INET_NTOA(NULL, NULL, NULL);) 2025.06.13 15:56:00.949539 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:01.060387 [ 45013 ] {549f9f1f-7029-4b5d-a698-0ef7be434abe} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 31, line 32) (in query: SELECT IPv4CIDRToRange(NULL, NULL, NULL);) 2025.06.13 15:56:01.142236 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:01.220459 [ 45013 ] {6dda7a72-14bf-432d-a512-387b98c72911} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 32, line 33) (in query: SELECT IPv4NumToString(NULL, NULL, NULL);) 2025.06.13 15:56:01.236183 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:01.291836 [ 45013 ] {4434b9cf-9e2f-4902-acef-a1e66ed2a104} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 33, line 34) (in query: SELECT IPv4NumToStringClassC(NULL, NULL, NULL);) 2025.06.13 15:56:01.307943 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:01.366156 [ 45013 ] {c109aedf-08bd-4c24-a163-b3b1b6654ed5} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 34, line 35) (in query: SELECT IPv4StringToNum(NULL, NULL, NULL);) 2025.06.13 15:56:01.372950 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:01.433053 [ 45013 ] {923d1ad6-de60-4870-98b6-2f2d1282e07e} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 35, line 36) (in query: SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL);) 2025.06.13 15:56:01.448954 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:01.613422 [ 45013 ] {2ed72429-9771-4e15-a281-1257dfa5d5cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 36, line 37) (in query: SELECT IPv4StringToNumOrNull(NULL, NULL, NULL);) 2025.06.13 15:56:01.625200 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:01.713406 [ 45013 ] {2fdfd925-365b-4324-be7d-d93f6be13e1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 37, line 38) (in query: SELECT IPv4ToIPv6(NULL, NULL, NULL);) 2025.06.13 15:56:01.721563 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:01.814289 [ 45013 ] {70bfe78c-3aa4-446b-ac8b-b803a55f06b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 38, line 39) (in query: SELECT IPv6CIDRToRange(NULL, NULL, NULL);) 2025.06.13 15:56:01.823415 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:01.899496 [ 45013 ] {a3022d13-8eb7-4190-be37-6354204aa63b} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 39, line 40) (in query: SELECT IPv6NumToString(NULL, NULL, NULL);) 2025.06.13 15:56:01.907305 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:01.969804 [ 45013 ] {f504c0e4-440e-4c0b-af41-fe958e64c804} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 40, line 41) (in query: SELECT IPv6StringToNum(NULL, NULL, NULL);) 2025.06.13 15:56:01.988261 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:02.048743 [ 45013 ] {b823d812-3361-43e1-91dd-1a6a4342b28e} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 41, line 42) (in query: SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL);) 2025.06.13 15:56:02.058044 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:02.113291 [ 45013 ] {6e3ddd13-f69f-4a5b-99e6-d983d2c6f2ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 42, line 43) (in query: SELECT IPv6StringToNumOrNull(NULL, NULL, NULL);) 2025.06.13 15:56:02.139486 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:02.187651 [ 45013 ] {3a045365-f1ab-41bf-b9df-a3e2e5517f71} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 43, line 44) (in query: SELECT JSONAllPaths(NULL, NULL, NULL);) 2025.06.13 15:56:02.228664 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:02.363918 [ 45013 ] {9e0226cc-c7ec-4bac-8e10-2b7b3f592a77} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 44, line 45) (in query: SELECT JSONAllPathsWithTypes(NULL, NULL, NULL);) 2025.06.13 15:56:02.373684 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:02.535502 [ 45013 ] {cb378d19-bdac-4a70-a5d3-2358be0bd4aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 45, line 46) (in query: SELECT JSONArrayLength(NULL, NULL, NULL);) 2025.06.13 15:56:02.546521 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:02.700144 [ 45013 ] {f3df0bb1-ba7a-450e-b171-31f412788b93} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 46, line 47) (in query: SELECT JSONDynamicPaths(NULL, NULL, NULL);) 2025.06.13 15:56:02.838246 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:02.912711 [ 45013 ] {a1fed879-3219-4482-a389-ed8128f90768} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 47, line 48) (in query: SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL);) 2025.06.13 15:56:02.921952 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:02.972187 [ 45013 ] {22bcf073-6f9a-4234-8170-95ac61da396e} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL, NULL). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 48, line 49) (in query: SELECT JSONExtract(NULL, NULL, NULL);) 2025.06.13 15:56:02.981054 [ 45013 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL, NULL). (ILLEGAL_COLUMN) 2025.06.13 15:56:03.889299 [ 45013 ] {ae77a46f-cb3e-4893-acbd-89356f5fe5af} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL, NULL). (ILLEGAL_COLUMN) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 54, line 55) (in query: SELECT JSONExtractKeysAndValues(NULL, NULL, NULL);) 2025.06.13 15:56:03.900632 [ 45013 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL, NULL). (ILLEGAL_COLUMN) 2025.06.13 15:56:04.411890 [ 8099 ] {b838888f-a450-4eb9-869a-b76129eb1e1c} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40528) (comment: 03375_bloom_filter_array_equals.sql) (query 1, line 1) (in query: CREATE TABLE test (`x` Array(String), INDEX idx1 x TYPE bloom_filter(0.025) GRANULARITY 1) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 64222, min_bytes_for_wide_part = 767073699, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 36, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 411815338, compact_parts_max_granules_to_buffer = 5, compact_parts_merge_max_bytes_to_prefetch_part = 21804746, merge_max_block_size = 12157, old_parts_lifetime = 426., prefer_fetch_merged_part_size_threshold = 9598859755, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3855046107, index_granularity_bytes = 26648481, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 63, 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 = 78401, primary_key_compress_block_size = 91776, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:04.435940 [ 8099 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:05.334406 [ 45013 ] {4de2d89d-2e74-43a0-823c-a0f9f9d9a7f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 63, line 64) (in query: SELECT JSONSharedDataPaths(NULL, NULL, NULL);) 2025.06.13 15:56:05.391255 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:05.525637 [ 45013 ] {79c2b6ee-5acc-4cd1-9de6-8294f1800db6} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 64, line 65) (in query: SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL);) 2025.06.13 15:56:05.545188 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:05.861891 [ 18510 ] {7e7ea741-695c-41da-b411-fa4bdca7f097} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 728, line 243) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:05.873457 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:05.890111 [ 45013 ] {5dd6bb86-3783-4161-830e-3b58c1914f41} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 66, line 67) (in query: SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL);) 2025.06.13 15:56:05.903185 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:06.417773 [ 45485 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:06.529783 [ 45013 ] {cb251e0a-6ef9-4e60-af35-24b1fa5a037a} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 70, line 71) (in query: SELECT L1Distance(NULL, NULL, NULL);) 2025.06.13 15:56:06.542253 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:06.647596 [ 45013 ] {4568236e-3c57-45a7-b37e-8ae413df8272} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 71, line 72) (in query: SELECT L1Norm(NULL, NULL, NULL);) 2025.06.13 15:56:06.661459 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:06.710806 [ 45013 ] {40a83d68-15cf-4ad3-8354-ffa501e70022} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 72, line 73) (in query: SELECT L1Normalize(NULL, NULL, NULL);) 2025.06.13 15:56:06.730062 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:06.801009 [ 45013 ] {ef14f120-5f6c-4391-ae99-184f9a851f7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 73, line 74) (in query: SELECT L2Distance(NULL, NULL, NULL);) 2025.06.13 15:56:06.827078 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:06.894267 [ 45013 ] {ee739fcf-787d-45f1-adeb-6203d30c699f} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 74, line 75) (in query: SELECT L2Norm(NULL, NULL, NULL);) 2025.06.13 15:56:06.913129 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:06.996085 [ 45013 ] {5267aab1-1904-4a35-9a71-d39f4753e02f} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 75, line 76) (in query: SELECT L2Normalize(NULL, NULL, NULL);) 2025.06.13 15:56:07.013265 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:07.043143 [ 18510 ] {55a452fe-6b88-4fe6-b4d9-7209b0f04f22} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 734, line 245) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:07.073419 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:07.144060 [ 45013 ] {fff41e2c-1b25-43fc-92af-fdd6f9ace4b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 76, line 77) (in query: SELECT L2SquaredDistance(NULL, NULL, NULL);) 2025.06.13 15:56:07.163253 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:07.254928 [ 45013 ] {6a8e705c-cc59-42e1-aa03-336553d63947} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 77, line 78) (in query: SELECT L2SquaredNorm(NULL, NULL, NULL);) 2025.06.13 15:56:07.266108 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:07.453298 [ 45013 ] {fd517543-b544-4105-93d4-c678d7201b6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 79, line 80) (in query: SELECT LinfDistance(NULL, NULL, NULL);) 2025.06.13 15:56:07.460856 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:07.631579 [ 18510 ] {ea07375b-f5bf-421c-8fae-aee7eb36dfae} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 737, line 246) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:07.638012 [ 45013 ] {c9829fc6-63ea-4c54-81fa-85ba88a20ab4} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 80, line 81) (in query: SELECT LinfNorm(NULL, NULL, NULL);) 2025.06.13 15:56:07.659302 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:07.668552 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:07.751068 [ 45013 ] {66f61295-5722-47d8-956c-18b8a95e156f} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 81, line 82) (in query: SELECT LinfNormalize(NULL, NULL, NULL);) 2025.06.13 15:56:07.760889 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:08.163495 [ 45013 ] {1d5801e4-8217-4020-a2e5-4a39c6551399} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 83, line 84) (in query: SELECT LpNorm(NULL, NULL, NULL);) 2025.06.13 15:56:08.170789 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:08.216945 [ 3708 ] {0d0afc2e-2181-4a22-b8eb-7a8f820cd572} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000014 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:08.244093 [ 3708 ] {0d0afc2e-2181-4a22-b8eb-7a8f820cd572} DDLWorker: Query /* ddl_entry=query-0000000014 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:08.295085 [ 45013 ] {3b404cad-eb86-443f-89f2-89cacbe67f84} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 84, line 85) (in query: SELECT LpNormalize(NULL, NULL, NULL);) 2025.06.13 15:56:08.341320 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:08.440999 [ 45013 ] {b2d66da7-487a-4ae0-ae86-22330307818b} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 85, line 86) (in query: SELECT MACNumToString(NULL, NULL, NULL);) 2025.06.13 15:56:08.467589 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:08.532867 [ 45013 ] {fcb66274-43c9-4505-a56f-b6eb19daea6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 86, line 87) (in query: SELECT MACStringToNum(NULL, NULL, NULL);) 2025.06.13 15:56:08.538063 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:08.607252 [ 45013 ] {e7643904-f921-4be8-a9ce-269237be7388} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 87, line 88) (in query: SELECT MACStringToOUI(NULL, NULL, NULL);) 2025.06.13 15:56:08.618985 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:08.670710 [ 5112 ] {fc964ed9-e773-46d9-ad2a-6e95041cec5c} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40626) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_mcvlsla7.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:56:08.697025 [ 5112 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:56:08.763029 [ 45013 ] {6a6d8288-607e-4895-882c-36b798be7487} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 88, line 89) (in query: SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL);) 2025.06.13 15:56:08.777809 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:08.844906 [ 45013 ] {d9dfe56d-d277-458d-8b19-de4826d6d04d} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 89, line 90) (in query: SELECT MD4(NULL, NULL, NULL);) 2025.06.13 15:56:08.854892 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:09.025960 [ 45013 ] {1935c457-25de-4b2e-a347-2b76756134ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 90, line 91) (in query: SELECT MD5(NULL, NULL, NULL);) 2025.06.13 15:56:09.059113 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:09.970856 [ 45013 ] {180420a6-7764-4311-a44c-beba501a47c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 94, line 95) (in query: SELECT OCTET_LENGTH(NULL, NULL, NULL);) 2025.06.13 15:56:09.980929 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:10.617366 [ 45013 ] {d7edad55-305d-46d7-aa06-87341479f6ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 97, line 98) (in query: SELECT REGEXP_MATCHES(NULL, NULL, NULL);) 2025.06.13 15:56:10.624238 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:11.009100 [ 45013 ] {5ffda72d-ea01-44b0-b257-3fb35da57609} executeQuery: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 3, should be 1: In scope SELECT RIPEMD160(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 99, line 100) (in query: SELECT RIPEMD160(NULL, NULL, NULL);) 2025.06.13 15:56:11.016057 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 3, should be 1: In scope SELECT RIPEMD160(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:11.196193 [ 45013 ] {ec97a8bd-0e8c-48de-8f9c-ac4ee002c447} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 100, line 101) (in query: SELECT SCHEMA(NULL, NULL, NULL);) 2025.06.13 15:56:11.196457 [ 18510 ] {5220dd3a-ea31-4294-bd43-d33348107e71} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 749, line 250) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:11.201578 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:11.207254 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:11.388340 [ 45013 ] {7b830b8e-1991-4962-b1fd-b5261a3f1762} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 102, line 103) (in query: SELECT SHA1(NULL, NULL, NULL);) 2025.06.13 15:56:11.398922 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:11.475009 [ 45013 ] {fa07d988-b3cf-4a32-a3d6-38d9cb70b3cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 103, line 104) (in query: SELECT SHA224(NULL, NULL, NULL);) 2025.06.13 15:56:11.483665 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:11.535650 [ 45013 ] {c060fd85-986d-499c-b4ea-7ce368935c50} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 104, line 105) (in query: SELECT SHA256(NULL, NULL, NULL);) 2025.06.13 15:56:11.551092 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:11.602716 [ 45013 ] {67714299-079a-4ee5-8b84-eab94ff67bb5} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 105, line 106) (in query: SELECT SHA384(NULL, NULL, NULL);) 2025.06.13 15:56:11.610063 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:11.785751 [ 45013 ] {e16e2e84-f394-46cd-b69e-e3142d78c857} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 106, line 107) (in query: SELECT SHA512(NULL, NULL, NULL);) 2025.06.13 15:56:11.801002 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:11.920110 [ 45013 ] {fcd3fa2e-6c03-4f03-94d7-3fa427013e41} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 107, line 108) (in query: SELECT SHA512_256(NULL, NULL, NULL);) 2025.06.13 15:56:11.975984 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:12.112192 [ 4098 ] {a5da8656-977d-423c-ae2d-0a0574f1f77c} executeQuery: Code: 70. DB::Exception: Value in column Int256 cannot be safely converted into type Int32: while executing 'FUNCTION in(i :: 0, __set_3328180927952712378_10493058491845264123 :: 1) -> in(__table1.i, __set_3328180927952712378_10493058491845264123) Nullable(UInt8) : 2'. (CANNOT_CONVERT_TYPE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40686) (comment: 02809_storage_set_analysis_bug.sql) (query 9, line 14) (in query: SELECT count() = 1 FROM null_in__fuzz_6 PREWHERE 71 WHERE i IN (test_set);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x000000002ae7b505 6. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)::operator()>, DB::DataTypeNumber>>(DB::DataTypeNumber const&) const @ 0x000000002ae7334a 7. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002ae71ae8 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002ae719b4 9. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002b0206e2 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, 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) @ 0x000000002b020454 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 16. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25278e 17. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e252fc4 18. ./build_docker/./src/Interpreters/Set.cpp:440: DB::Set::execute(std::vector> const&, bool) const @ 0x000000002df4b191 19. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000001c1e1330 20. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c1e08d0 21. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 23. DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace68cd 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5864 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 27. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 29. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 30. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 31. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 2025.06.13 15:56:12.118110 [ 4098 ] {} TCPHandler: Code: 70. DB::Exception: Value in column Int256 cannot be safely converted into type Int32: while executing 'FUNCTION in(i :: 0, __set_3328180927952712378_10493058491845264123 :: 1) -> in(__table1.i, __set_3328180927952712378_10493058491845264123) Nullable(UInt8) : 2'. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x000000002ae7b505 6. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)::operator()>, DB::DataTypeNumber>>(DB::DataTypeNumber const&) const @ 0x000000002ae7334a 7. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002ae71ae8 8. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002ae719b4 9. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002b0206e2 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, 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) @ 0x000000002b020454 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002ad7f4f2 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace8029 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002acea447 16. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e25278e 17. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x000000002e252fc4 18. ./build_docker/./src/Interpreters/Set.cpp:440: DB::Set::execute(std::vector> const&, bool) const @ 0x000000002df4b191 19. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000001c1e1330 20. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c1e08d0 21. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002acf1bce 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace58f7 23. DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace68cd 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace5864 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace82fa 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002ace9910 27. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::executeAction(DB::ExpressionActions::Action const&, DB::(anonymous namespace)::ExecutionContext&, bool, bool) @ 0x000000002d626a95 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:770: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000002d624287 29. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000031dc2537 30. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000031dc22c0 31. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x00000000288fb017 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:56:12.292977 [ 2993 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000287b921c 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x000000002d5f8b30 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x000000002d5f92c1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:12.583485 [ 3708 ] {743114ed-cc16-4ce2-9af2-ee1e8edd97fe} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000016 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:12.590555 [ 3708 ] {743114ed-cc16-4ce2-9af2-ee1e8edd97fe} DDLWorker: Query /* ddl_entry=query-0000000016 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:12.726235 [ 7279 ] {76eaea9c-30da-4f45-a2a1-7905669fcf51} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:40728) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_mcvlsla7.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:56:12.740673 [ 7279 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:56:13.271726 [ 45013 ] {7ef60bf9-769d-4158-af15-f23d1f8855ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 114, line 115) (in query: SELECT TO_BASE64(NULL, NULL, NULL);) 2025.06.13 15:56:13.282621 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:14.109736 [ 18510 ] {0315495a-b3c8-4e94-94f1-59f6aa88b437} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 758, line 253) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:14.120500 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:14.243100 [ 45013 ] {1ac36f8b-e9ac-4786-aaac-a1f22a00f2b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 119, line 120) (in query: SELECT URLHierarchy(NULL, NULL, NULL);) 2025.06.13 15:56:14.251753 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:14.329841 [ 45013 ] {398aec76-2b55-4150-a79d-a6c6ee727936} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 120, line 121) (in query: SELECT URLPathHierarchy(NULL, NULL, NULL);) 2025.06.13 15:56:14.337545 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:14.470182 [ 45013 ] {07fe9b66-c221-4a19-b01e-ca286ee42102} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 121, line 122) (in query: SELECT UTCTimestamp(NULL, NULL, NULL);) 2025.06.13 15:56:14.487733 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:14.583588 [ 45013 ] {551439ac-6766-400d-8b74-318e2bfc4f2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 122, line 123) (in query: SELECT UTC_timestamp(NULL, NULL, NULL);) 2025.06.13 15:56:14.683645 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:16.242707 [ 3708 ] {d6287b74-21de-4af2-bc37-811f3c152b32} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000018 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:16.248624 [ 3708 ] {d6287b74-21de-4af2-bc37-811f3c152b32} DDLWorker: Query /* ddl_entry=query-0000000018 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:16.339568 [ 45013 ] {4651d953-b749-467b-90d9-df29df538027} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 134, line 135) (in query: SELECT _CAST(NULL, NULL, NULL);) 2025.06.13 15:56:16.347986 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:16.459118 [ 45511 ] {8d9081d8-ca04-4c75-bf96-cafb30789e41} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55752) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_mcvlsla7.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:56:16.480631 [ 45511 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:56:16.487570 [ 45013 ] {289a24b8-1f2d-45a1-91b8-614169930bd7} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 135, line 136) (in query: SELECT __actionName(NULL, NULL, NULL);) 2025.06.13 15:56:16.571332 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:16.641927 [ 45013 ] {dd42c702-bfbb-462b-8fda-e5bf69e0f313} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 136, line 137) (in query: SELECT __bitBoolMaskAnd(NULL, NULL, NULL);) 2025.06.13 15:56:16.649427 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:16.783976 [ 45013 ] {b716defa-78d3-4001-a00f-df5c08fa8a91} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 137, line 138) (in query: SELECT __bitBoolMaskOr(NULL, NULL, NULL);) 2025.06.13 15:56:16.866414 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:16.930425 [ 45013 ] {c2e8fe4f-e655-4a14-92c2-4de544ad9656} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 138, line 139) (in query: SELECT __bitSwapLastTwo(NULL, NULL, NULL);) 2025.06.13 15:56:16.945667 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:16.998597 [ 45013 ] {80f1916a-d6ba-49b9-a40f-b1856795eca0} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 139, line 140) (in query: SELECT __bitWrapperFunc(NULL, NULL, NULL);) 2025.06.13 15:56:17.006650 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:17.069336 [ 45013 ] {794fc998-4f7b-43ca-8017-be9335e40edd} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 140, line 141) (in query: SELECT __getScalar(NULL, NULL, NULL);) 2025.06.13 15:56:17.075601 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:17.136978 [ 45013 ] {9b8c04e3-2b0c-4e94-888c-7ff71cdfa071} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 141, line 142) (in query: SELECT __scalarSubqueryResult(NULL, NULL, NULL);) 2025.06.13 15:56:17.174185 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:17.283000 [ 45013 ] {6ca815f1-0f76-4f4a-ba7c-d1dbb21fe7a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 142, line 143) (in query: SELECT abs(NULL, NULL, NULL);) 2025.06.13 15:56:17.294057 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:17.382938 [ 45013 ] {8ac774b1-f677-4ee3-b928-4522fb83cee4} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 143, line 144) (in query: SELECT accurateCast(NULL, NULL, NULL);) 2025.06.13 15:56:17.408440 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:17.457482 [ 3708 ] {d6a53f1e-3726-4162-9f86-0382ca294cc9} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000019 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:17.463230 [ 3708 ] {d6a53f1e-3726-4162-9f86-0382ca294cc9} DDLWorker: Query /* ddl_entry=query-0000000019 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:17.482064 [ 45013 ] {1c966518-f3c6-453f-b5ed-031733514191} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 144, line 145) (in query: SELECT accurateCastOrDefault(NULL, NULL, NULL);) 2025.06.13 15:56:17.490348 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:56:17.602552 [ 45013 ] {f7241bcf-4896-4f00-ba33-64c82f745a29} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 145, line 146) (in query: SELECT accurateCastOrNull(NULL, NULL, NULL);) 2025.06.13 15:56:17.621908 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:17.672338 [ 45013 ] {44e62951-4fa8-4aa6-b824-0b187dc9d07f} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 146, line 147) (in query: SELECT acos(NULL, NULL, NULL);) 2025.06.13 15:56:17.680977 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:17.783665 [ 7279 ] {f6ceb6af-1e86-43fb-8cf2-e70ffc25e26d} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55820) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_mcvlsla7.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:56:17.796522 [ 7279 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:56:17.808674 [ 45013 ] {fab8ce55-c1ff-4ded-981f-835ff86583dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 147, line 148) (in query: SELECT acosh(NULL, NULL, NULL);) 2025.06.13 15:56:17.822407 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:17.959086 [ 45013 ] {8e5c2135-347b-4c4f-98c0-67e7f6c1e71b} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 148, line 149) (in query: SELECT addDate(NULL, NULL, NULL);) 2025.06.13 15:56:17.977051 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:18.523401 [ 18510 ] {b8740fc4-488d-4668-bcd7-332a46449d58} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 773, line 258) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:18.532224 [ 45013 ] {98787481-6a3b-492d-a188-86974d5c749b} executeQuery: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 151, line 152) (in query: SELECT addInterval(NULL, NULL, NULL);) 2025.06.13 15:56:18.545036 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:18.571178 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:18.821046 [ 3708 ] {1e6fb7a7-2d9e-4abe-be32-175662ea0e4d} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000020 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:18.831943 [ 3708 ] {1e6fb7a7-2d9e-4abe-be32-175662ea0e4d} DDLWorker: Query /* ddl_entry=query-0000000020 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:18.946368 [ 4098 ] {fd93b74d-ab02-4f23-a02a-d3f90d994903} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55842) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_mcvlsla7.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:56:18.966563 [ 4098 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:56:19.694422 [ 45013 ] {1f5ad83d-4f79-4423-8ef2-c0364b1d7eca} executeQuery: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 159, line 160) (in query: SELECT addTupleOfIntervals(NULL, NULL, NULL);) 2025.06.13 15:56:19.730071 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:19.907615 [ 3708 ] {082ffa35-6a9f-4fcd-9ae4-73757a3955cf} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000021 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:19.916369 [ 3708 ] {082ffa35-6a9f-4fcd-9ae4-73757a3955cf} DDLWorker: Query /* ddl_entry=query-0000000021 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:20.027005 [ 4098 ] {71c6b916-deda-431a-9229-3bf7c9c52fed} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55876) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_mcvlsla7.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:56:20.042328 [ 4098 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:56:20.220267 [ 45013 ] {fe2cc8ea-10fe-4c59-b84f-e55b431c75b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 162, line 163) (in query: SELECT addressToLine(NULL, NULL, NULL);) 2025.06.13 15:56:20.254616 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:20.425382 [ 45013 ] {c07c9a41-8442-40b1-aeb7-0ab6eb115ad9} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 163, line 164) (in query: SELECT addressToLineWithInlines(NULL, NULL, NULL);) 2025.06.13 15:56:20.437190 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:20.484467 [ 45013 ] {aaebd015-3b5a-4833-bd6a-f3f8915421d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 164, line 165) (in query: SELECT addressToSymbol(NULL, NULL, NULL);) 2025.06.13 15:56:20.492357 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:21.522209 [ 3708 ] {180c4039-1985-4b1d-931a-34d19db94778} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01671_ddl_hang_timeout_long_test_mcvlsla7/test_01671/replicas/r_5). (TABLE_IS_READ_ONLY) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000022 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000030587a41 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6427: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003067c7c7 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5cb284 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c4049 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:56:21.536544 [ 3708 ] {180c4039-1985-4b1d-931a-34d19db94778} DDLWorker: Query /* ddl_entry=query-0000000022 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01671_ddl_hang_timeout_long_test_mcvlsla7/test_01671/replicas/r_5). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000018d3b4cf 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5937: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000030587a41 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6427: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003067c7c7 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5cb284 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c4049 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:22.268416 [ 45013 ] {7fb4a544-bad3-4067-8d38-f58ff1d76792} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 176, line 177) (in query: SELECT anyLastRespectNulls(NULL, NULL, NULL);) 2025.06.13 15:56:22.279020 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:22.321168 [ 45013 ] {6a4c1a1e-65c7-4551-b938-429af20735ea} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 177, line 178) (in query: SELECT anyLast_respect_nulls(NULL, NULL, NULL);) 2025.06.13 15:56:22.359971 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:22.477476 [ 45013 ] {ebed8c8a-698a-496d-b16d-4456abda981b} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 178, line 179) (in query: SELECT anyRespectNulls(NULL, NULL, NULL);) 2025.06.13 15:56:22.495394 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:22.526339 [ 3708 ] {} DDLWorker: , task query-0000000022 will not be executed. 2025.06.13 15:56:22.565388 [ 45013 ] {e33d0b3d-a58e-4a49-a4c7-f32cfd102af5} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 179, line 180) (in query: SELECT anyValueRespectNulls(NULL, NULL, NULL);) 2025.06.13 15:56:22.582005 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:22.668981 [ 45013 ] {3bdd0029-14c8-438e-b2f4-d9136d9b2a84} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 180, line 181) (in query: SELECT any_respect_nulls(NULL, NULL, NULL);) 2025.06.13 15:56:22.681048 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:22.730526 [ 7279 ] {91dc732f-dcc3-409d-8e07-1dbb1cfb3603} executeQuery: Code: 341. DB::Exception: There was an error on [localhost:9000]: Cannot execute replicated DDL query, table is dropped or detached permanently. (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:55926) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_mcvlsla7.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:56:22.740647 [ 7279 ] {} TCPHandler: Code: 341. DB::Exception: There was an error on [localhost:9000]: Cannot execute replicated DDL query, table is dropped or detached permanently. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:56:23.018219 [ 18510 ] {d27fb4bd-db71-4746-b64f-ef3f49c7af59} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 788, line 263) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:23.019853 [ 45013 ] {20126fdd-b135-426b-8b89-1dbe8641ba98} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 182, line 183) (in query: SELECT any_value_respect_nulls(NULL, NULL, NULL);) 2025.06.13 15:56:23.030752 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:23.031057 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:23.229391 [ 45013 ] {dbb444e7-85ef-418d-9b61-f9cda2ae7f73} executeQuery: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 183, line 184) (in query: SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL);) 2025.06.13 15:56:23.240440 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:23.571306 [ 3708 ] {5408fd27-febf-46da-b9c1-d62f64c9be87} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000023 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:23.576858 [ 3708 ] {5408fd27-febf-46da-b9c1-d62f64c9be87} DDLWorker: Query /* ddl_entry=query-0000000023 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:23.843438 [ 4098 ] {c5dbe391-b07d-4447-9f67-feeaa08e5889} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45900) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_mcvlsla7.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:56:23.855206 [ 4098 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:56:24.125257 [ 44700 ] {dc367c76-393b-42e8-b80a-2a89b6fd03ea} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42332) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (query 112, line 134) (in query: SELECT sum(2 - decimal32) From test_table;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:56:24.152797 [ 44700 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:56:24.684738 [ 3708 ] {9d8d9257-608d-4fa5-8a3e-8df3960f1524} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000024 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:24.686776 [ 3708 ] {9d8d9257-608d-4fa5-8a3e-8df3960f1524} DDLWorker: Query /* ddl_entry=query-0000000024 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000017ce8fcf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc42754 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c40e5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:24.913271 [ 4098 ] {377a6fb8-aca7-4337-833b-2e5f340eb6cb} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45922) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_mcvlsla7.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:56:24.927131 [ 4098 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.3.20286.altinityantalya (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:56:25.673417 [ 45013 ] {1f87ffb6-6307-4159-a53c-b1a155a546c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 200, line 201) (in query: SELECT arrayDistinct(NULL, NULL, NULL);) 2025.06.13 15:56:25.680483 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:25.718713 [ 45013 ] {fe5bd627-23e0-49b6-8136-1596382c603f} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 201, line 202) (in query: SELECT arrayDotProduct(NULL, NULL, NULL);) 2025.06.13 15:56:25.724919 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:25.786453 [ 45013 ] {c88a49aa-c81c-43c2-b459-96831729ba8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 202, line 203) (in query: SELECT arrayElement(NULL, NULL, NULL);) 2025.06.13 15:56:25.808505 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:26.081812 [ 45013 ] {e2daa07b-f923-4d8c-ad00-7304c0decdd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 3, should be 2: In scope SELECT arrayElementOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 203, line 204) (in query: SELECT arrayElementOrNull(NULL, NULL, NULL);) 2025.06.13 15:56:26.089502 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 3, should be 2: In scope SELECT arrayElementOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:26.224772 [ 45013 ] {b8f2f1b8-9e0d-4d82-914c-b7791f7890f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 204, line 205) (in query: SELECT arrayEnumerate(NULL, NULL, NULL);) 2025.06.13 15:56:26.239392 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:26.746559 [ 3708 ] {dbd70ea3-f5ab-4ffc-89b6-4d83c9d7b02d} executeQuery: Code: 341. DB::Exception: Some replicas doesn't finish metadata alter: Log entry log-0000000000 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000025 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7188: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x000000003067b3d3 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6713: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000306830b7 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5cb284 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c4049 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:56:26.751322 [ 3708 ] {dbd70ea3-f5ab-4ffc-89b6-4d83c9d7b02d} DDLWorker: Query /* ddl_entry=query-0000000025 */ ALTER TABLE test_mcvlsla7.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 341. DB::Exception: Some replicas doesn't finish metadata alter: Log entry log-0000000000 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000017ccddef 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7188: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x000000003067b3d3 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6713: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000306830b7 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002dc41371 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000002dc3e5b1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c6e56 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x000000002d5cb284 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x000000002d5c4049 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002d5bff0f 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x000000002d5b43b6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x000000002d5df914 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:27.005045 [ 3708 ] {} DDLWorker: , task query-0000000025 will not be executed. 2025.06.13 15:56:27.140320 [ 7279 ] {b84f8320-4e54-4fc1-b34a-0133e9dd3eea} executeQuery: Code: 341. DB::Exception: There was an error on [localhost:9000]: Cannot execute replicated DDL query, table is dropped or detached permanently. (UNFINISHED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:45954) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_mcvlsla7.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 2025.06.13 15:56:27.157710 [ 7279 ] {} TCPHandler: Code: 341. DB::Exception: There was an error on [localhost:9000]: Cannot execute replicated DDL query, table is dropped or detached permanently. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x000000002e28f43a 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000002d618d81 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x0000000031802779 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x0000000031801fc3 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003181a025 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031834937 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 15. ? @ 0x00007f2f4224dac3 16. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000318332ad 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003183399d 6. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000316b8e25 7. ./build_docker/./src/Server/TCPHandler.cpp:677: DB::TCPHandler::runImpl() @ 0x00000000316a44f9 8. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:56:27.427280 [ 18510 ] {bd9d9998-39d2-4aae-be76-31c109ea1e4e} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 806, line 269) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:27.437307 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:27.450897 [ 45013 ] {d27e59b0-79aa-4afa-91f3-c4ddf19a46a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 215, line 216) (in query: SELECT arrayFlatten(NULL, NULL, NULL);) 2025.06.13 15:56:27.463774 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:27.512188 [ 45013 ] {12eada11-c765-42e5-bee2-5af7951d1738} executeQuery: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 216, line 217) (in query: SELECT arrayFold(NULL, NULL, NULL);) 2025.06.13 15:56:27.521046 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:56:27.786369 [ 45013 ] {360cc1e5-f65f-4f2a-a50f-531065286925} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 218, line 219) (in query: SELECT arrayJaccardIndex(NULL, NULL, NULL);) 2025.06.13 15:56:27.795371 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:27.844138 [ 45013 ] {998e0d50-af9c-4855-8de6-0ae47cdc0c09} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 219, line 220) (in query: SELECT arrayJoin(NULL, NULL, NULL);) 2025.06.13 15:56:27.854675 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:27.929314 [ 18510 ] {e9ddbc1d-63a2-4b2b-aa52-a7d19a3ec44b} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 809, line 270) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:27.938694 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:28.430690 [ 7279 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:28.687616 [ 45013 ] {411caf34-5271-487c-ba5e-290df8e053c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 3, should be 2: In scope SELECT arrayNormalizedGini(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 226, line 227) (in query: SELECT arrayNormalizedGini(NULL, NULL, NULL);) 2025.06.13 15:56:28.710848 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 3, should be 2: In scope SELECT arrayNormalizedGini(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:29.289499 [ 45013 ] {64ef3d30-8e8a-4e9b-8a86-67a989ba9655} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 231, line 232) (in query: SELECT arrayPopBack(NULL, NULL, NULL);) 2025.06.13 15:56:29.299668 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:29.347361 [ 45013 ] {8f943c0c-6206-4d1e-b5c2-bd2d485b1d0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 232, line 233) (in query: SELECT arrayPopFront(NULL, NULL, NULL);) 2025.06.13 15:56:29.374428 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:29.629913 [ 45013 ] {4fad2769-1bbc-421f-9517-e566df9e046a} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 234, line 235) (in query: SELECT arrayPushBack(NULL, NULL, NULL);) 2025.06.13 15:56:29.640113 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:29.678381 [ 45013 ] {be87ad42-0875-4bfd-a12e-44661eb45dc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 235, line 236) (in query: SELECT arrayPushFront(NULL, NULL, NULL);) 2025.06.13 15:56:29.685668 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:29.828020 [ 45013 ] {95ab2690-c115-4913-a247-37f6acead26b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 237, line 238) (in query: SELECT arrayRandomSample(NULL, NULL, NULL);) 2025.06.13 15:56:29.834651 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:29.876900 [ 45013 ] {c475bdf3-626b-45b3-89fa-7a4e339c7c4f} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 238, line 239) (in query: SELECT arrayReduce(NULL, NULL, NULL);) 2025.06.13 15:56:29.883780 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:56:29.982204 [ 45013 ] {f99c68f2-2094-4834-975a-578182cb8fcf} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array' to function 'arrayResize'. Expected: Array, got: Nullable(Nothing): In scope SELECT arrayResize(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 240, line 241) (in query: SELECT arrayResize(NULL, NULL, NULL);) 2025.06.13 15:56:29.989687 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array' to function 'arrayResize'. Expected: Array, got: Nullable(Nothing): In scope SELECT arrayResize(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:56:30.134268 [ 45013 ] {2fb06ec7-b454-44a7-abed-c86f8e3773c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 241, line 242) (in query: SELECT arrayReverse(NULL, NULL, NULL);) 2025.06.13 15:56:30.147052 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:30.671035 [ 45013 ] {02fbf1bc-7f23-47d4-98bd-fca8a410b3d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 245, line 246) (in query: SELECT arrayRotateLeft(NULL, NULL, NULL);) 2025.06.13 15:56:30.718779 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:30.768882 [ 45013 ] {77459c1f-272d-4771-b608-5dc61d6b48ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 246, line 247) (in query: SELECT arrayRotateRight(NULL, NULL, NULL);) 2025.06.13 15:56:30.776961 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:30.962753 [ 45013 ] {523034f6-a453-48bc-b737-66589b6c2bc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 249, line 250) (in query: SELECT arrayShingles(NULL, NULL, NULL);) 2025.06.13 15:56:30.989858 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:30.997097 [ 18510 ] {9cba08ec-5d48-4862-b057-d89bff132ee2} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 827, line 276) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:31.010186 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:31.753012 [ 18510 ] {e7350d33-d7e4-4c35-91a8-e7cea7d2dfe7} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 833, line 278) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:31.800408 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:31.898045 [ 45013 ] {48659fcc-f727-414a-96ab-638a0db077fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 259, line 260) (in query: SELECT arrayWithConstant(NULL, NULL, NULL);) 2025.06.13 15:56:31.905129 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:32.149240 [ 45013 ] {084ec91e-4242-46ca-8f6a-5fd9fa192853} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 263, line 264) (in query: SELECT array_concat_agg(NULL, NULL, NULL);) 2025.06.13 15:56:32.154666 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:56:32.195151 [ 45013 ] {2eaae5a8-30dd-4a5c-8b4b-711938182674} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 264, line 265) (in query: SELECT ascii(NULL, NULL, NULL);) 2025.06.13 15:56:32.201189 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:32.203439 [ 18510 ] {089ad839-ced6-43f3-8e90-9b5bf4bd49e3} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 836, line 279) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:32.209215 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:32.237211 [ 45013 ] {d690cd2f-b9c8-4839-8065-5736adc02789} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 265, line 266) (in query: SELECT asin(NULL, NULL, NULL);) 2025.06.13 15:56:32.243107 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:32.281281 [ 45013 ] {8931e134-d101-45f8-8774-bb7200b8b947} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 266, line 267) (in query: SELECT asinh(NULL, NULL, NULL);) 2025.06.13 15:56:32.289667 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:32.356077 [ 45013 ] {3013edea-ad55-4055-abbf-11182b70cfb8} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 267, line 268) (in query: SELECT assumeNotNull(NULL, NULL, NULL);) 2025.06.13 15:56:32.362599 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:32.413763 [ 45013 ] {1218602c-f4e8-45b7-8ab8-0c5cb035b60c} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 268, line 269) (in query: SELECT atan(NULL, NULL, NULL);) 2025.06.13 15:56:32.421439 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:32.489137 [ 45013 ] {65ce82ad-be14-4945-a099-900cca45d779} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 269, line 270) (in query: SELECT atan2(NULL, NULL, NULL);) 2025.06.13 15:56:32.494628 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:32.522199 [ 45013 ] {eb7d2276-f568-4a0d-9a99-933b2af02cf1} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 270, line 271) (in query: SELECT atanh(NULL, NULL, NULL);) 2025.06.13 15:56:32.527935 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:32.763738 [ 45013 ] {f57dc6d6-af37-458c-823f-38732e820f0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 274, line 275) (in query: SELECT base58Decode(NULL, NULL, NULL);) 2025.06.13 15:56:32.770434 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:32.804879 [ 45013 ] {182856cf-7f48-4524-a4a4-72c77da98bdb} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 275, line 276) (in query: SELECT base58Encode(NULL, NULL, NULL);) 2025.06.13 15:56:32.811163 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:32.843622 [ 45013 ] {432403c2-c152-4778-99e5-6ef4cf508ca2} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 276, line 277) (in query: SELECT base64Decode(NULL, NULL, NULL);) 2025.06.13 15:56:32.853276 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:32.894715 [ 45013 ] {5a02ae47-b830-4db3-8f63-5b500c2e70f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 277, line 278) (in query: SELECT base64Encode(NULL, NULL, NULL);) 2025.06.13 15:56:32.901070 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:32.983106 [ 45013 ] {c84d7c76-0af9-468b-bdfc-15b9d91b4e33} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 278, line 279) (in query: SELECT base64URLDecode(NULL, NULL, NULL);) 2025.06.13 15:56:32.991298 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:33.030885 [ 45013 ] {e7ac68bb-9502-4700-b464-249207ce58d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 279, line 280) (in query: SELECT base64URLEncode(NULL, NULL, NULL);) 2025.06.13 15:56:33.037786 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:33.077541 [ 45013 ] {08f514b4-a9fb-425e-b084-f334bac6e419} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 280, line 281) (in query: SELECT basename(NULL, NULL, NULL);) 2025.06.13 15:56:33.095116 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:33.138791 [ 45013 ] {8298675c-3b7b-4c0f-be1e-ae0864b9eed6} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 281, line 282) (in query: SELECT bin(NULL, NULL, NULL);) 2025.06.13 15:56:33.146536 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:33.241515 [ 45013 ] {3f168989-b9e2-43d7-845c-8ecb30ab7202} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 282, line 283) (in query: SELECT bitAnd(NULL, NULL, NULL);) 2025.06.13 15:56:33.247255 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:33.313309 [ 45013 ] {c8673b4c-d005-4935-a17c-450bba23c894} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 283, line 284) (in query: SELECT bitCount(NULL, NULL, NULL);) 2025.06.13 15:56:33.318716 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:33.349839 [ 45013 ] {a29732af-6427-4413-bb76-22fc083a4ae0} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 284, line 285) (in query: SELECT bitHammingDistance(NULL, NULL, NULL);) 2025.06.13 15:56:33.356891 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:33.384020 [ 45013 ] {39805c94-470b-4f44-8834-02154f9ad240} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 285, line 286) (in query: SELECT bitNot(NULL, NULL, NULL);) 2025.06.13 15:56:33.390881 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:33.429060 [ 45013 ] {6b17d3db-7170-46e9-b173-77258966b4c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 286, line 287) (in query: SELECT bitOr(NULL, NULL, NULL);) 2025.06.13 15:56:33.441975 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:33.486848 [ 45013 ] {c3df94f7-5e67-4b11-a14e-f626e2566ecb} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 287, line 288) (in query: SELECT bitPositionsToArray(NULL, NULL, NULL);) 2025.06.13 15:56:33.494873 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:33.530401 [ 45013 ] {99383fa5-52d7-4f4a-9f2b-f1358f7ce200} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 288, line 289) (in query: SELECT bitRotateLeft(NULL, NULL, NULL);) 2025.06.13 15:56:33.536750 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:33.620473 [ 45013 ] {c0bc305d-7bb3-408d-b7df-d7a7749d6d14} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 289, line 290) (in query: SELECT bitRotateRight(NULL, NULL, NULL);) 2025.06.13 15:56:33.629544 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:33.697813 [ 45013 ] {24aff04c-6be6-4ad0-a502-357e15a8fd33} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 290, line 291) (in query: SELECT bitShiftLeft(NULL, NULL, NULL);) 2025.06.13 15:56:33.706500 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:33.776990 [ 45013 ] {6d1adfd3-625a-4257-acde-96ae54d27b0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 291, line 292) (in query: SELECT bitShiftRight(NULL, NULL, NULL);) 2025.06.13 15:56:33.784307 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:33.840033 [ 18510 ] {513a1f3c-66a8-4fb3-a426-5ecf104bfa67} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 846, line 282) (in query: INSERT INTO mt_00763_2 SELECT toString(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:56:33.863978 [ 18510 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:56:34.014902 [ 45013 ] {b07c33d4-08c1-47da-87a0-fb038def4f77} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 293, line 294) (in query: SELECT bitTest(NULL, NULL, NULL);) 2025.06.13 15:56:34.057706 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:34.316946 [ 45013 ] {a893f815-6483-4427-bcea-8da2d7f40020} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 296, line 297) (in query: SELECT bitXor(NULL, NULL, NULL);) 2025.06.13 15:56:34.323960 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:34.361283 [ 45013 ] {bfd133e9-9e05-4bf9-adcc-0307038d5301} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 297, line 298) (in query: SELECT bitmapAnd(NULL, NULL, NULL);) 2025.06.13 15:56:34.366613 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:34.397847 [ 45013 ] {1faac5b1-ed8d-42bb-8378-d9086882cb4d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 298, line 299) (in query: SELECT bitmapAndCardinality(NULL, NULL, NULL);) 2025.06.13 15:56:34.405494 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:34.435425 [ 45013 ] {4c21caae-56a1-4ebd-9fa2-e0a53a228a0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 299, line 300) (in query: SELECT bitmapAndnot(NULL, NULL, NULL);) 2025.06.13 15:56:34.441115 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:34.475770 [ 45013 ] {e62873f9-d76d-405c-959d-09f67eae53b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 300, line 301) (in query: SELECT bitmapAndnotCardinality(NULL, NULL, NULL);) 2025.06.13 15:56:34.483045 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:34.519347 [ 45013 ] {7c532cb6-3f5d-4b9f-bb29-94db4b7a43fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 301, line 302) (in query: SELECT bitmapBuild(NULL, NULL, NULL);) 2025.06.13 15:56:34.527252 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:34.610068 [ 45013 ] {7bd3a19d-0234-4ab1-b122-3490ce55c324} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 302, line 303) (in query: SELECT bitmapCardinality(NULL, NULL, NULL);) 2025.06.13 15:56:34.619826 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:34.701253 [ 45013 ] {2985969d-5aef-42d5-9ca3-a04540f7cb8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 303, line 304) (in query: SELECT bitmapContains(NULL, NULL, NULL);) 2025.06.13 15:56:34.706708 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:34.732397 [ 45013 ] {accee304-63c7-40ae-9e28-f75b56423a39} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 304, line 305) (in query: SELECT bitmapHasAll(NULL, NULL, NULL);) 2025.06.13 15:56:34.738733 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:34.814895 [ 45013 ] {b154b577-626e-4319-8100-bb52f1d3d357} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 305, line 306) (in query: SELECT bitmapHasAny(NULL, NULL, NULL);) 2025.06.13 15:56:34.822734 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:34.975384 [ 45013 ] {c0bd2b22-0af9-4993-8769-783b1945bede} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 306, line 307) (in query: SELECT bitmapMax(NULL, NULL, NULL);) 2025.06.13 15:56:34.990928 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:35.024387 [ 45013 ] {eb7cfb4c-0742-4cb8-847a-464eaf8e3711} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 307, line 308) (in query: SELECT bitmapMin(NULL, NULL, NULL);) 2025.06.13 15:56:35.034083 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:35.105093 [ 45013 ] {beed1391-ffe4-419a-b350-cd809b653efb} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 308, line 309) (in query: SELECT bitmapOr(NULL, NULL, NULL);) 2025.06.13 15:56:35.111741 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:35.143340 [ 45013 ] {335fdee4-a1a2-4d35-a2a0-e9f3cde3a3f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 309, line 310) (in query: SELECT bitmapOrCardinality(NULL, NULL, NULL);) 2025.06.13 15:56:35.159196 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:35.502592 [ 45013 ] {f88563b9-fc22-4e4b-94c7-a386c0d0613d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 312, line 313) (in query: SELECT bitmapToArray(NULL, NULL, NULL);) 2025.06.13 15:56:35.511218 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:35.695467 [ 45013 ] {d6beef89-eb50-4a80-a1aa-056574131d93} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 314, line 315) (in query: SELECT bitmapXor(NULL, NULL, NULL);) 2025.06.13 15:56:35.704710 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:35.776251 [ 45013 ] {2df4c827-0559-4324-a9eb-6cdd7a12b152} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 315, line 316) (in query: SELECT bitmapXorCardinality(NULL, NULL, NULL);) 2025.06.13 15:56:35.784230 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:35.920033 [ 45013 ] {116e19e3-1910-4a94-b905-03b3e3d62057} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 316, line 317) (in query: SELECT bitmaskToArray(NULL, NULL, NULL);) 2025.06.13 15:56:35.928171 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:35.962722 [ 45013 ] {a01da543-2acb-453f-9805-78d81535385f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 317, line 318) (in query: SELECT bitmaskToList(NULL, NULL, NULL);) 2025.06.13 15:56:35.970212 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:36.009618 [ 45013 ] {0516b3b6-cd74-407a-8f0e-0c2c31a82b44} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 318, line 319) (in query: SELECT blockNumber(NULL, NULL, NULL);) 2025.06.13 15:56:36.020879 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:36.144916 [ 45013 ] {4905b530-3d0c-49ab-92dc-2f3b84305067} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 320, line 321) (in query: SELECT blockSize(NULL, NULL, NULL);) 2025.06.13 15:56:36.150313 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:36.322284 [ 45013 ] {015ebff9-34ca-47de-be14-35d7105abaa8} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 322, line 323) (in query: SELECT buildId(NULL, NULL, NULL);) 2025.06.13 15:56:36.393530 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:36.429889 [ 45013 ] {1338085b-87d7-40e8-a032-4771aafe6499} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 323, line 324) (in query: SELECT byteHammingDistance(NULL, NULL, NULL);) 2025.06.13 15:56:36.436752 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:36.727160 [ 45013 ] {831cf878-beff-4565-9f4c-696748e56471} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 326, line 327) (in query: SELECT byteSwap(NULL, NULL, NULL);) 2025.06.13 15:56:36.734362 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:37.174685 [ 45013 ] {7d9389d0-5948-4ae9-a5b4-7ccde054cb52} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 331, line 332) (in query: SELECT catboostEvaluate(NULL, NULL, NULL);) 2025.06.13 15:56:37.189136 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:56:37.223607 [ 45013 ] {5600d453-e546-4623-82b9-c27d326b75be} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 332, line 333) (in query: SELECT categoricalInformationValue(NULL, NULL, NULL);) 2025.06.13 15:56:37.230046 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:56:37.294119 [ 45013 ] {7fec92f4-a614-487d-996a-606b876114c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 333, line 334) (in query: SELECT cbrt(NULL, NULL, NULL);) 2025.06.13 15:56:37.309814 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:37.367082 [ 18510 ] {c995f029-528f-45a7-b5ea-9bccfdb1502d} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 866, line 289) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:37.398129 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:37.701783 [ 45013 ] {5555e94f-f920-4180-a5cd-61e6b7f7062a} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 336, line 337) (in query: SELECT changeDay(NULL, NULL, NULL);) 2025.06.13 15:56:37.710817 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:37.756339 [ 45013 ] {ea5e06f8-a0de-4ffb-bc19-c0e08b18e93b} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 337, line 338) (in query: SELECT changeHour(NULL, NULL, NULL);) 2025.06.13 15:56:37.763268 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:37.824778 [ 45013 ] {6f1d5173-2cc1-48e6-a294-ec7d520213c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 338, line 339) (in query: SELECT changeMinute(NULL, NULL, NULL);) 2025.06.13 15:56:37.831036 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:37.868089 [ 45013 ] {5e9b7b98-dd1a-4640-afc9-b388ce5e150f} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 339, line 340) (in query: SELECT changeMonth(NULL, NULL, NULL);) 2025.06.13 15:56:37.892348 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:37.932875 [ 45013 ] {d2b86380-35b5-4080-8f96-89e4984b26fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 340, line 341) (in query: SELECT changeSecond(NULL, NULL, NULL);) 2025.06.13 15:56:37.940019 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:37.994804 [ 45013 ] {88b5173c-7510-4210-b853-b8c67509ecc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 341, line 342) (in query: SELECT changeYear(NULL, NULL, NULL);) 2025.06.13 15:56:38.003086 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:38.062383 [ 42488 ] {ad172f94-6d81-4ba2-9f41-397165d16364} BackupsWorker: Failed to restore from backup Disk('backups', 'test_kgrqeo7s_02911_keeper_map'): Code: 159. DB::Exception: Timeout exceeded: elapsed 106324.956492 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Backups/RestorerFromBackup.cpp:276: DB::RestorerFromBackup::setStage(String const&, String const&) @ 0x000000002c01583b 8. ./build_docker/./src/Backups/RestorerFromBackup.cpp:175: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x000000002c0129d5 9. ./build_docker/./src/Backups/BackupsWorker.cpp:948: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf40b09 10. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 11. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 13. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39634 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e48 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:38.071713 [ 44676 ] {ad172f94-6d81-4ba2-9f41-397165d16364} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 106324.956492 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:35028) (comment: 02911_backup_restore_keeper_map.sh) (query 1, line 1) (in query: RESTORE DATABASE test_kgrqeo7s_02911_keeper_map FROM Disk('backups', 'test_kgrqeo7s_02911_keeper_map');), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Backups/RestorerFromBackup.cpp:276: DB::RestorerFromBackup::setStage(String const&, String const&) @ 0x000000002c01583b 8. ./build_docker/./src/Backups/RestorerFromBackup.cpp:175: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x000000002c0129d5 9. ./build_docker/./src/Backups/BackupsWorker.cpp:948: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf40b09 10. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 11. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 13. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:56:38.091368 [ 44676 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 106324.956492 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002c3ae80f 5. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002c3adbfe 6. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x000000002dee8910 7. ./build_docker/./src/Backups/RestorerFromBackup.cpp:276: DB::RestorerFromBackup::setStage(String const&, String const&) @ 0x000000002c01583b 8. ./build_docker/./src/Backups/RestorerFromBackup.cpp:175: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x000000002c0129d5 9. ./build_docker/./src/Backups/BackupsWorker.cpp:948: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002bf40b09 10. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002bf53792 11. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002bf48743 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002b8312fc 13. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002b831732 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002b830459 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002b8302b7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002bf39634 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bf38e48 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x000000002e36f5dc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 11. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 12. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 2025.06.13 15:56:39.968869 [ 45013 ] {227940c9-4e69-463f-a17e-f6baa5898f46} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 352, line 353) (in query: SELECT connectionId(NULL, NULL, NULL);) 2025.06.13 15:56:39.977088 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:40.139141 [ 45013 ] {8fb4155e-5c15-44d5-a429-7ff6b19e673d} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 353, line 354) (in query: SELECT connection_id(NULL, NULL, NULL);) 2025.06.13 15:56:40.147445 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:40.578271 [ 18510 ] {b5160bde-7be9-4c11-9942-629c5b0e7aac} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 881, line 294) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:40.614897 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:41.013683 [ 45013 ] {c0396a50-8dc4-4703-bbc8-79309107dff4} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 359, line 360) (in query: SELECT cos(NULL, NULL, NULL);) 2025.06.13 15:56:41.029237 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:41.090872 [ 45013 ] {c3e1a63b-4f08-4e38-a99b-908654cbbe4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 360, line 361) (in query: SELECT cosh(NULL, NULL, NULL);) 2025.06.13 15:56:41.097391 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:41.151538 [ 45013 ] {25f404c5-ae32-4d5d-bc8c-ba21f4d4dcaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 361, line 362) (in query: SELECT cosineDistance(NULL, NULL, NULL);) 2025.06.13 15:56:41.161226 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:41.319651 [ 45013 ] {db0c4d76-bcac-42e9-9e4a-cc178cd79064} executeQuery: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 362, line 363) (in query: SELECT count(NULL, NULL, NULL);) 2025.06.13 15:56:41.418880 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:41.447654 [ 45013 ] {426f3917-c093-4729-85b1-279676c4c6a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 363, line 364) (in query: SELECT countDigits(NULL, NULL, NULL);) 2025.06.13 15:56:41.454135 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:41.510687 [ 45013 ] {81f73452-f57f-4f56-bf30-407f1e2687da} executeQuery: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 364, line 365) (in query: SELECT countEqual(NULL, NULL, NULL);) 2025.06.13 15:56:41.521757 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:41.652134 [ 45013 ] {f0a5784c-015f-4639-9cec-13d61d17936f} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 365, line 366) (in query: SELECT countMatches(NULL, NULL, NULL);) 2025.06.13 15:56:41.659325 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:41.695705 [ 45013 ] {d2c3124c-a416-4891-989a-aeff1e8d169d} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 366, line 367) (in query: SELECT countMatchesCaseInsensitive(NULL, NULL, NULL);) 2025.06.13 15:56:41.701925 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:42.983124 [ 45013 ] {ad8a29a1-ba46-416c-b331-1b49fe2a6617} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 378, line 379) (in query: SELECT curdate(NULL, NULL, NULL);) 2025.06.13 15:56:42.990672 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:43.050459 [ 45013 ] {f73a2ba7-7052-4917-af90-ef3f7c66fb42} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 379, line 380) (in query: SELECT currentDatabase(NULL, NULL, NULL);) 2025.06.13 15:56:43.057730 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:43.118875 [ 45013 ] {eab28eec-90b3-42df-8be3-fb8b2db0ae89} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 380, line 381) (in query: SELECT currentProfiles(NULL, NULL, NULL);) 2025.06.13 15:56:43.172078 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:43.204342 [ 45013 ] {81db93b5-d142-4f77-a04d-3f92d7bda8e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT currentQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 381, line 382) (in query: SELECT currentQueryID(NULL, NULL, NULL);) 2025.06.13 15:56:43.209830 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT currentQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:43.329118 [ 45013 ] {ab0ca7e5-967a-4d94-8b36-392e0dc7ec87} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 382, line 383) (in query: SELECT currentRoles(NULL, NULL, NULL);) 2025.06.13 15:56:43.334969 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:43.364891 [ 45013 ] {e35d8a55-73bb-4650-a4cd-efe9d6a25c84} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 383, line 384) (in query: SELECT currentSchemas(NULL, NULL, NULL);) 2025.06.13 15:56:43.372704 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:43.404754 [ 45013 ] {e82bf884-2a18-40f0-aa36-86e0b449e0b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 384, line 385) (in query: SELECT currentUser(NULL, NULL, NULL);) 2025.06.13 15:56:43.411038 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:43.442048 [ 45013 ] {7edb45fb-f3ed-426e-930b-be1e2d7f9a1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 385, line 386) (in query: SELECT current_database(NULL, NULL, NULL);) 2025.06.13 15:56:43.449951 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:43.485923 [ 45013 ] {ab2b6f3b-fa53-4be1-a2a2-090d30a20a8a} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 386, line 387) (in query: SELECT current_date(NULL, NULL, NULL);) 2025.06.13 15:56:43.491472 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:43.528817 [ 45013 ] {35beb380-fd81-4fe9-b015-c10025f10f9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT current_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 387, line 388) (in query: SELECT current_query_id(NULL, NULL, NULL);) 2025.06.13 15:56:43.534799 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT current_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:43.563852 [ 45013 ] {2fa4854b-e772-4324-9db7-54525e6a6608} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 388, line 389) (in query: SELECT current_schemas(NULL, NULL, NULL);) 2025.06.13 15:56:43.570400 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:43.719763 [ 45013 ] {94ebb938-e435-45c6-9eeb-061250d180a9} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 389, line 390) (in query: SELECT current_timestamp(NULL, NULL, NULL);) 2025.06.13 15:56:43.750488 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:43.878802 [ 45013 ] {b03523ce-7ed0-4997-92d2-6da55b4ccbac} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 390, line 391) (in query: SELECT current_user(NULL, NULL, NULL);) 2025.06.13 15:56:43.951449 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:43.988779 [ 45013 ] {5ff19065-9a7b-4ded-bb44-04a3016b8f40} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 391, line 392) (in query: SELECT cutFragment(NULL, NULL, NULL);) 2025.06.13 15:56:43.996502 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:44.172654 [ 45013 ] {23393eab-c7f5-4f76-8738-748b6b370af9} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 393, line 394) (in query: SELECT cutQueryString(NULL, NULL, NULL);) 2025.06.13 15:56:44.183469 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:44.287840 [ 45013 ] {9f7303a3-80c2-48c2-afca-98b50ebfbafe} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 394, line 395) (in query: SELECT cutQueryStringAndFragment(NULL, NULL, NULL);) 2025.06.13 15:56:44.295098 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:44.358939 [ 45013 ] {5ffb7788-3cad-4d19-a162-5eb248623a50} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 395, line 396) (in query: SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL);) 2025.06.13 15:56:44.376701 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:44.456158 [ 45013 ] {03d7eb97-c235-4677-bec4-71e8fb5edcab} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 396, line 397) (in query: SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL);) 2025.06.13 15:56:44.462488 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:44.562298 [ 45013 ] {a99fcdb0-225f-4eff-8a04-ece3336f5eb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 397, line 398) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL);) 2025.06.13 15:56:44.568663 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:44.674643 [ 45013 ] {55d50648-f04b-4bc1-bd3b-af104570029f} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 398, line 399) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL);) 2025.06.13 15:56:44.693335 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:44.744962 [ 45013 ] {2e05b81f-cc7f-4b2f-ba9d-e78e4b84fc15} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 399, line 400) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL);) 2025.06.13 15:56:44.758868 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:44.832430 [ 45013 ] {aaf62048-7d6f-44e3-9de5-c6686d527438} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 400, line 401) (in query: SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL);) 2025.06.13 15:56:44.857439 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:44.948284 [ 45013 ] {59feb975-bacb-48d8-96b4-d28b618a3208} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 401, line 402) (in query: SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL);) 2025.06.13 15:56:44.967046 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:45.026315 [ 45013 ] {5c709967-433a-4226-85bb-b7dcef82ccff} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 402, line 403) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL);) 2025.06.13 15:56:45.032084 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:45.159147 [ 45013 ] {0dead5fe-f8d4-47a9-9e02-7a875cafddc4} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 403, line 404) (in query: SELECT cutURLParameter(NULL, NULL, NULL);) 2025.06.13 15:56:45.166211 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:45.201436 [ 45013 ] {47eb1209-a515-4b38-b83f-dad6a8cdca97} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 404, line 405) (in query: SELECT cutWWW(NULL, NULL, NULL);) 2025.06.13 15:56:45.208772 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:45.274588 [ 45013 ] {fadcd461-be8c-46d1-a8e6-281419a17b36} executeQuery: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 405, line 406) (in query: SELECT damerauLevenshteinDistance(NULL, NULL, NULL);) 2025.06.13 15:56:45.292048 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:45.550734 [ 45013 ] {e62a192d-a335-47da-9298-a00f772d0874} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 408, line 409) (in query: SELECT dateTime64ToSnowflake(NULL, NULL, NULL);) 2025.06.13 15:56:45.557654 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:45.676010 [ 45013 ] {5f1f26c1-a2f2-4747-9b68-2f2419cab85f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 410, line 411) (in query: SELECT dateTimeToSnowflake(NULL, NULL, NULL);) 2025.06.13 15:56:45.681920 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:46.186505 [ 18510 ] {a71fe8da-2771-4a5a-b1ca-081d9430a0c0} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 914, line 305) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:46.194296 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:46.267755 [ 45013 ] {4747b100-1cc2-46e6-b5db-03effa8d9e31} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 415, line 416) (in query: SELECT decodeHTMLComponent(NULL, NULL, NULL);) 2025.06.13 15:56:46.275746 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:46.310159 [ 45013 ] {174e1d24-3c64-4e90-947b-fd404239a971} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 416, line 417) (in query: SELECT decodeURLComponent(NULL, NULL, NULL);) 2025.06.13 15:56:46.315350 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:46.351628 [ 45013 ] {c0b7995a-a827-4a03-b3c9-39a644274683} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 417, line 418) (in query: SELECT decodeURLFormComponent(NULL, NULL, NULL);) 2025.06.13 15:56:46.357871 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:46.395293 [ 45013 ] {3c7ceb6f-1eb2-4d3c-873a-f92d472bf699} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 418, line 419) (in query: SELECT decodeXMLComponent(NULL, NULL, NULL);) 2025.06.13 15:56:46.402868 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:46.485392 [ 18510 ] {82f961b3-aecc-4e41-929c-da3ebd25c361} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 917, line 306) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:46.491822 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:46.496124 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:46.505391 [ 45013 ] {f9149298-e801-4a5e-9e1f-643c51bfb99a} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 420, line 421) (in query: SELECT defaultProfiles(NULL, NULL, NULL);) 2025.06.13 15:56:46.511685 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:46.553380 [ 45013 ] {e6a63419-c4b5-4d88-8e42-b174969070f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 421, line 422) (in query: SELECT defaultRoles(NULL, NULL, NULL);) 2025.06.13 15:56:46.579824 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:46.628473 [ 45013 ] {0623bcd7-5911-4c07-a3a1-ed7303559b1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 422, line 423) (in query: SELECT defaultValueOfArgumentType(NULL, NULL, NULL);) 2025.06.13 15:56:46.636884 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:46.675222 [ 45013 ] {8e05f379-a056-472f-906f-0ef96fde06a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 423, line 424) (in query: SELECT defaultValueOfTypeName(NULL, NULL, NULL);) 2025.06.13 15:56:46.737276 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:46.806153 [ 45013 ] {ba6f6e10-acfa-4682-a9ea-dc1d57c4a173} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 424, line 425) (in query: SELECT degrees(NULL, NULL, NULL);) 2025.06.13 15:56:46.819606 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:46.868627 [ 45013 ] {da3483f6-1114-4c6f-9043-58cfcb9b5f75} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 425, line 426) (in query: SELECT deltaSum(NULL, NULL, NULL);) 2025.06.13 15:56:46.886637 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:47.007659 [ 45013 ] {5bab4f16-ad26-4d92-95f6-4293d7702a2e} executeQuery: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 426, line 427) (in query: SELECT deltaSumTimestamp(NULL, NULL, NULL);) 2025.06.13 15:56:47.013892 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:47.057962 [ 45013 ] {fc502b16-bcc3-4cf9-b1a9-003ae76dd65e} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 427, line 428) (in query: SELECT demangle(NULL, NULL, NULL);) 2025.06.13 15:56:47.065652 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:47.147742 [ 45013 ] {cc60e928-a195-4465-806d-cea6ed0e54d2} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 428, line 429) (in query: SELECT denseRank(NULL, NULL, NULL);) 2025.06.13 15:56:47.160549 [ 45013 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:56:47.356712 [ 45013 ] {509b93f9-b9bf-4593-ba84-c92b3af1130b} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 429, line 430) (in query: SELECT dense_rank(NULL, NULL, NULL);) 2025.06.13 15:56:47.364915 [ 45013 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:56:47.451515 [ 45013 ] {63b9341a-2d91-42da-9bf5-207a9348df4f} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 430, line 431) (in query: SELECT detectCharset(NULL, NULL, NULL);) 2025.06.13 15:56:47.458118 [ 45013 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:56:47.521731 [ 45013 ] {f8ffdfcd-9f88-43d0-8502-3a3c24c060ac} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 431, line 432) (in query: SELECT detectLanguage(NULL, NULL, NULL);) 2025.06.13 15:56:47.535056 [ 45013 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:56:47.583410 [ 45013 ] {d7bc7726-e558-4ab9-add8-dd3fa49ed31c} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 432, line 433) (in query: SELECT detectLanguageMixed(NULL, NULL, NULL);) 2025.06.13 15:56:47.591421 [ 45013 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:56:47.630398 [ 45013 ] {634edda3-00c0-4dfc-a393-16285bf6d65b} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 433, line 434) (in query: SELECT detectLanguageUnknown(NULL, NULL, NULL);) 2025.06.13 15:56:47.636624 [ 45013 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:56:47.664234 [ 45013 ] {c38a3446-2ca9-480b-85c9-678cd8eb6270} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 434, line 435) (in query: SELECT detectProgrammingLanguage(NULL, NULL, NULL);) 2025.06.13 15:56:47.668558 [ 45013 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:56:47.703631 [ 45013 ] {61c72db1-22a3-4f9e-8b7f-048ed1c13d6a} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 435, line 436) (in query: SELECT detectTonality(NULL, NULL, NULL);) 2025.06.13 15:56:47.709867 [ 45013 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:56:47.779006 [ 45013 ] {746a0d30-440a-4ff2-8178-3975326c1baf} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 436, line 437) (in query: SELECT dictGet(NULL, NULL, NULL);) 2025.06.13 15:56:47.795732 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:56:47.842053 [ 45013 ] {88e220a1-a084-448f-97b8-173bed5c883a} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 437, line 438) (in query: SELECT dictGetAll(NULL, NULL, NULL);) 2025.06.13 15:56:47.850930 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:56:47.894838 [ 45013 ] {e3cea7ec-a090-4314-9dc6-cc847b44ba4c} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 438, line 439) (in query: SELECT dictGetChildren(NULL, NULL, NULL);) 2025.06.13 15:56:47.900896 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:48.281031 [ 7279 ] {8bf3a57f-2adf-48c2-8cda-d8899fd9148e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53372) (comment: 02911_backup_restore_keeper_map.sh) (query 1, line 1) (in query: DROP DATABASE test_kgrqeo7s_02911_keeper_map SYNC;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:56:48.309943 [ 7279 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 12. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 13. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 18. ? @ 0x00007f2f4224dac3 19. ? @ 0x00007f2f422df850 2025.06.13 15:56:48.362877 [ 45013 ] {216de78d-b229-4851-8faa-0af37eace96b} executeQuery: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL, NULL). (UNSUPPORTED_METHOD) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 443, line 444) (in query: SELECT dictGetDescendants(NULL, NULL, NULL);) 2025.06.13 15:56:48.376139 [ 45013 ] {} TCPHandler: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL, NULL). (UNSUPPORTED_METHOD) 2025.06.13 15:56:48.967207 [ 45013 ] {308bfb96-8901-4815-8bc6-76e4ea633f91} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 448, line 449) (in query: SELECT dictGetHierarchy(NULL, NULL, NULL);) 2025.06.13 15:56:48.978364 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:50.246038 [ 18510 ] {eeee2bad-e21e-4596-b039-51a456d9b0da} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 935, line 312) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:50.253250 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:50.805359 [ 45013 ] {37f13c9e-b095-47b0-a9e4-5a19fe6cfb64} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 461, line 462) (in query: SELECT dictGetOrDefault(NULL, NULL, NULL);) 2025.06.13 15:56:50.827094 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:56:50.878619 [ 45013 ] {a585bfa9-8010-46c4-8abc-acd2a729aaf6} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 462, line 463) (in query: SELECT dictGetOrNull(NULL, NULL, NULL);) 2025.06.13 15:56:50.904271 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:56:52.510353 [ 45013 ] {4a214ea8-bdbc-4b36-b6ec-ea97fe4d6bbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 477, line 478) (in query: SELECT displayName(NULL, NULL, NULL);) 2025.06.13 15:56:52.517284 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:52.567269 [ 45013 ] {48c4e842-3182-4f83-b64c-4dae3c098cf6} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 478, line 479) (in query: SELECT distanceL1(NULL, NULL, NULL);) 2025.06.13 15:56:52.583879 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:52.810392 [ 45013 ] {9677ef00-73cf-4692-8a03-8df3c10d0cc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 479, line 480) (in query: SELECT distanceL2(NULL, NULL, NULL);) 2025.06.13 15:56:52.816400 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:52.856570 [ 45013 ] {21feb116-32bc-4cd3-b6b7-03f0115b168f} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 480, line 481) (in query: SELECT distanceL2Squared(NULL, NULL, NULL);) 2025.06.13 15:56:52.862834 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:52.965354 [ 45013 ] {11f52c4b-850b-498b-996f-5d75e21ea174} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 481, line 482) (in query: SELECT distanceLinf(NULL, NULL, NULL);) 2025.06.13 15:56:52.970957 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:53.379776 [ 45013 ] {4dab8b81-fe0f-4a01-8730-fcddfe8b5b00} executeQuery: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 486, line 487) (in query: SELECT divide(NULL, NULL, NULL);) 2025.06.13 15:56:53.385675 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:53.559254 [ 45013 ] {49ff9cfb-a7d7-47e7-9761-c494610eb41d} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 488, line 489) (in query: SELECT domain(NULL, NULL, NULL);) 2025.06.13 15:56:53.566166 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:53.609558 [ 45013 ] {6f2cb28a-b8db-4238-a73c-ec1d66b58ac1} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 489, line 490) (in query: SELECT domainRFC(NULL, NULL, NULL);) 2025.06.13 15:56:53.616861 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:53.653275 [ 45013 ] {43f5a98b-dd01-48c2-a259-c1d79308b4de} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 490, line 491) (in query: SELECT domainWithoutWWW(NULL, NULL, NULL);) 2025.06.13 15:56:53.660260 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:53.696476 [ 45013 ] {7a8cd540-3b63-43ff-aadd-a19fe2e01592} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 491, line 492) (in query: SELECT domainWithoutWWWRFC(NULL, NULL, NULL);) 2025.06.13 15:56:53.702946 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:53.802849 [ 45013 ] {0c9ff257-e274-4df5-a108-d307ec6a8ecb} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 492, line 493) (in query: SELECT dotProduct(NULL, NULL, NULL);) 2025.06.13 15:56:53.811236 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:53.840732 [ 45013 ] {ab75f013-3ebd-406e-b418-1d1261b00557} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 493, line 494) (in query: SELECT dumpColumnStructure(NULL, NULL, NULL);) 2025.06.13 15:56:53.846441 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:53.884768 [ 45013 ] {702bfbba-a07f-404c-92d8-733b3d00bc8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 494, line 495) (in query: SELECT dynamicElement(NULL, NULL, NULL);) 2025.06.13 15:56:53.889156 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:53.912251 [ 45013 ] {4b40826f-43b1-4b05-a83a-f077199ee376} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 495, line 496) (in query: SELECT dynamicType(NULL, NULL, NULL);) 2025.06.13 15:56:53.917289 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:53.937916 [ 45013 ] {b90e0de2-5c18-4d40-afcc-cf49c75490f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 496, line 497) (in query: SELECT e(NULL, NULL, NULL);) 2025.06.13 15:56:53.942491 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:53.965537 [ 45013 ] {e07545b5-5087-4132-bfd6-f347803768e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 497, line 498) (in query: SELECT editDistance(NULL, NULL, NULL);) 2025.06.13 15:56:53.971325 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.017049 [ 45013 ] {5fef6c4d-3975-425c-bb37-8242cd936c88} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 498, line 499) (in query: SELECT editDistanceUTF8(NULL, NULL, NULL);) 2025.06.13 15:56:54.023173 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.059194 [ 45013 ] {8a4b6549-a7c1-467c-bf1e-6c610eb55c05} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 499, line 500) (in query: SELECT empty(NULL, NULL, NULL);) 2025.06.13 15:56:54.063345 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.088735 [ 45013 ] {8df73218-67ca-4e64-b3fc-b0d68781cfe7} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 500, line 501) (in query: SELECT emptyArrayDate(NULL, NULL, NULL);) 2025.06.13 15:56:54.097754 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.131376 [ 45013 ] {c4a27aff-eb36-46ba-89b9-b34b8c0f0ddf} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 501, line 502) (in query: SELECT emptyArrayDateTime(NULL, NULL, NULL);) 2025.06.13 15:56:54.137644 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.180661 [ 45013 ] {e03507c2-c645-4d1d-a259-cb5f0a54e6c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 502, line 503) (in query: SELECT emptyArrayFloat32(NULL, NULL, NULL);) 2025.06.13 15:56:54.186500 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.262442 [ 45013 ] {ea6703ff-92fe-4c50-8f12-149afb5ea839} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 503, line 504) (in query: SELECT emptyArrayFloat64(NULL, NULL, NULL);) 2025.06.13 15:56:54.267019 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.297783 [ 45013 ] {eb31648c-22f2-4576-b1e5-acbd66bbe4b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 504, line 505) (in query: SELECT emptyArrayInt16(NULL, NULL, NULL);) 2025.06.13 15:56:54.303747 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.336443 [ 45013 ] {82ce7f7e-59d0-4f90-aba1-9e54748cc4c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 505, line 506) (in query: SELECT emptyArrayInt32(NULL, NULL, NULL);) 2025.06.13 15:56:54.343251 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.473571 [ 45013 ] {1be8c3dd-3ce9-4e37-8f18-a9f8415a7845} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 506, line 507) (in query: SELECT emptyArrayInt64(NULL, NULL, NULL);) 2025.06.13 15:56:54.552956 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.581789 [ 45013 ] {6539f6c2-d587-44b3-8b7d-61139c9ba19c} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 507, line 508) (in query: SELECT emptyArrayInt8(NULL, NULL, NULL);) 2025.06.13 15:56:54.586902 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.630570 [ 45013 ] {1726a3ba-81d7-4125-b385-99ac93801405} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 508, line 509) (in query: SELECT emptyArrayString(NULL, NULL, NULL);) 2025.06.13 15:56:54.638496 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.725839 [ 45013 ] {69748c16-d8f9-4e2f-99bb-1d58c8fcd22f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 509, line 510) (in query: SELECT emptyArrayToSingle(NULL, NULL, NULL);) 2025.06.13 15:56:54.735301 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.769787 [ 45013 ] {757cd844-c501-452a-9934-016edf53a88f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 510, line 511) (in query: SELECT emptyArrayUInt16(NULL, NULL, NULL);) 2025.06.13 15:56:54.778215 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.814382 [ 45013 ] {b0e9d82c-9d97-4ffe-8a08-ef28d52c0e93} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 511, line 512) (in query: SELECT emptyArrayUInt32(NULL, NULL, NULL);) 2025.06.13 15:56:54.821789 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.851197 [ 45013 ] {08c845da-801a-4eb1-8b48-38cd90f83bcc} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 512, line 513) (in query: SELECT emptyArrayUInt64(NULL, NULL, NULL);) 2025.06.13 15:56:54.857055 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.889480 [ 45013 ] {be8b6400-6430-474c-8aab-3a3a75d0d4b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 513, line 514) (in query: SELECT emptyArrayUInt8(NULL, NULL, NULL);) 2025.06.13 15:56:54.896411 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:54.926759 [ 45013 ] {1615909f-45cf-4726-95bf-770a883a333a} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 514, line 515) (in query: SELECT enabledProfiles(NULL, NULL, NULL);) 2025.06.13 15:56:54.933262 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:55.022441 [ 45013 ] {12a9f67e-9ea3-481f-8c56-84df7a12d8a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 515, line 516) (in query: SELECT enabledRoles(NULL, NULL, NULL);) 2025.06.13 15:56:55.030394 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:55.073969 [ 45013 ] {e29ec5a2-f174-43a5-a6a0-652987c9b489} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 516, line 517) (in query: SELECT encodeURLComponent(NULL, NULL, NULL);) 2025.06.13 15:56:55.082701 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:55.115244 [ 45013 ] {978d7117-53d1-44d7-9aea-179e64379d04} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 517, line 518) (in query: SELECT encodeURLFormComponent(NULL, NULL, NULL);) 2025.06.13 15:56:55.121362 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:55.341839 [ 45013 ] {ebe83e41-7e3e-4c97-98c1-e25f51dea1e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 518, line 519) (in query: SELECT encodeXMLComponent(NULL, NULL, NULL);) 2025.06.13 15:56:55.353515 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:55.474550 [ 45013 ] {7f64aab1-c397-4399-9341-653e39054202} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 520, line 521) (in query: SELECT endsWith(NULL, NULL, NULL);) 2025.06.13 15:56:55.479761 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:55.521465 [ 45013 ] {ef2d204c-0f31-452a-bde2-038011b34472} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 521, line 522) (in query: SELECT endsWithUTF8(NULL, NULL, NULL);) 2025.06.13 15:56:55.546286 [ 2860 ] {5034f520-cb37-49b1-b7db-02f6244b0476} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:53728) (comment: 02383_analyzer_merge_tree_self_join.sql) (in query: DROP DATABASE IF EXISTS test_o7vw6asy SYNC ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 15:56:55.546352 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:55.549503 [ 2860 ] {5034f520-cb37-49b1-b7db-02f6244b0476} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000017cd44af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000002d5ed696 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000002dcac264 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x000000002dca4b99 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000002dca3a15 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x000000002dca2f58 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:56:55.755089 [ 45013 ] {12e9dd83-0a54-4e87-885e-fcc09facf9cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 523, line 524) (in query: SELECT equals(NULL, NULL, NULL);) 2025.06.13 15:56:55.927886 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:55.962658 [ 45013 ] {502ed9e3-a61a-42fe-8408-320db5a746b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 524, line 525) (in query: SELECT erf(NULL, NULL, NULL);) 2025.06.13 15:56:55.969206 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:56.012831 [ 45013 ] {c21b4f99-eaeb-4a46-93e1-9da1170bbc70} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 525, line 526) (in query: SELECT erfc(NULL, NULL, NULL);) 2025.06.13 15:56:56.020557 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:56.050018 [ 45013 ] {41e97663-625a-45e6-9df6-7abac2b0a603} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 526, line 527) (in query: SELECT errorCodeToName(NULL, NULL, NULL);) 2025.06.13 15:56:56.056263 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:56.087109 [ 45013 ] {a75128e2-91e5-44fc-bbc5-aa6de718378d} executeQuery: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 527, line 528) (in query: SELECT estimateCompressionRatio(NULL, NULL, NULL);) 2025.06.13 15:56:56.093833 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:56.304912 [ 45013 ] {bd2028fa-34be-452c-9700-03163f8cdae0} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 529, line 530) (in query: SELECT exp(NULL, NULL, NULL);) 2025.06.13 15:56:56.314743 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:56.357568 [ 45013 ] {0bdaf922-b3fa-4052-9775-c0b8632fddd3} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 530, line 531) (in query: SELECT exp10(NULL, NULL, NULL);) 2025.06.13 15:56:56.365253 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:56.409140 [ 45013 ] {129d701c-056e-4e2d-8760-c71ff904f174} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 531, line 532) (in query: SELECT exp2(NULL, NULL, NULL);) 2025.06.13 15:56:56.449403 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:56.612437 [ 45013 ] {91b64835-d230-45a4-a2bb-4a90ca708baf} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 533, line 534) (in query: SELECT exponentialTimeDecayedAvg(NULL, NULL, NULL);) 2025.06.13 15:56:56.620837 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:56.841179 [ 45013 ] {99d6b84d-4280-4ace-b047-4bdbdf5c7ad3} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 534, line 535) (in query: SELECT exponentialTimeDecayedCount(NULL, NULL, NULL);) 2025.06.13 15:56:56.849583 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:56.967157 [ 45013 ] {7d6112cc-9b93-4a1d-83db-b2585c4c1ec9} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 535, line 536) (in query: SELECT exponentialTimeDecayedMax(NULL, NULL, NULL);) 2025.06.13 15:56:56.977101 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:57.049296 [ 45013 ] {6fefab42-cb2c-4f24-af5e-6bb22b345366} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 536, line 537) (in query: SELECT exponentialTimeDecayedSum(NULL, NULL, NULL);) 2025.06.13 15:56:57.061766 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:57.127101 [ 45013 ] {fb1bcf02-43bb-404e-bacc-c977d4833bc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 537, line 538) (in query: SELECT extract(NULL, NULL, NULL);) 2025.06.13 15:56:57.134026 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:57.199036 [ 45013 ] {c3f7c53b-3fc9-49c1-abe4-928fcc9bb2db} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 538, line 539) (in query: SELECT extractAll(NULL, NULL, NULL);) 2025.06.13 15:56:57.211027 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:57.245474 [ 45013 ] {d859b64f-ad4e-4a29-9654-303229514b87} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 539, line 540) (in query: SELECT extractAllGroups(NULL, NULL, NULL);) 2025.06.13 15:56:57.251782 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:57.300053 [ 45013 ] {ce52cefd-fb6b-4ea9-9f5b-11dd4d327217} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 540, line 541) (in query: SELECT extractAllGroupsHorizontal(NULL, NULL, NULL);) 2025.06.13 15:56:57.306355 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:57.355500 [ 45013 ] {ebc56dd3-2f2e-41e1-8694-b91cd375562a} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 541, line 542) (in query: SELECT extractAllGroupsVertical(NULL, NULL, NULL);) 2025.06.13 15:56:57.360880 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:57.414902 [ 45013 ] {719c9f01-302e-4d36-9fc5-a819d4823ad3} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 542, line 543) (in query: SELECT extractGroups(NULL, NULL, NULL);) 2025.06.13 15:56:57.496669 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:57.805725 [ 45013 ] {e7a60875-f8c2-45a3-be7c-d2b19ee7b5e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 545, line 546) (in query: SELECT extractTextFromHTML(NULL, NULL, NULL);) 2025.06.13 15:56:57.813357 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:57.852411 [ 45013 ] {09c9a7b4-0f38-4ad1-af20-c6080a43010f} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 546, line 547) (in query: SELECT extractURLParameter(NULL, NULL, NULL);) 2025.06.13 15:56:57.859367 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:57.914306 [ 45013 ] {a78b18d2-051b-4ea6-8190-6d400fa97d96} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 547, line 548) (in query: SELECT extractURLParameterNames(NULL, NULL, NULL);) 2025.06.13 15:56:57.928950 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:57.963267 [ 45013 ] {3e0152ba-d9ee-4080-95d8-62a59d5c0c77} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 548, line 549) (in query: SELECT extractURLParameters(NULL, NULL, NULL);) 2025.06.13 15:56:57.968844 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:58.096419 [ 45013 ] {04bdb148-af48-4bb5-a2d1-7e03edc95732} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 549, line 550) (in query: SELECT factorial(NULL, NULL, NULL);) 2025.06.13 15:56:58.103988 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:58.288493 [ 18510 ] {184a74c8-5cc4-4431-b8a6-498e1815c69c} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 983, line 328) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:58.310032 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:56:58.382697 [ 45013 ] {f4badd4e-ba3b-46ec-abf2-3a78ee7f7112} executeQuery: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 552, line 553) (in query: SELECT file(NULL, NULL, NULL);) 2025.06.13 15:56:58.410242 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:58.940385 [ 45013 ] {944b4323-8f41-4865-9c9b-1f28f750e499} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 556, line 557) (in query: SELECT finalizeAggregation(NULL, NULL, NULL);) 2025.06.13 15:56:58.948269 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:59.019406 [ 45013 ] {b9cc2100-0120-44b5-af56-4cdbec343711} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 557, line 558) (in query: SELECT firstLine(NULL, NULL, NULL);) 2025.06.13 15:56:59.026812 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:59.089505 [ 45013 ] {38cb8f6c-e3e2-470f-9c0a-198ac31b49c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 558, line 559) (in query: SELECT firstSignificantSubdomain(NULL, NULL, NULL);) 2025.06.13 15:56:59.096084 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:59.184732 [ 45013 ] {e199005b-cd68-413e-8722-fb019bcdcede} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 559, line 560) (in query: SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL);) 2025.06.13 15:56:59.200434 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:59.258840 [ 45013 ] {0a8adb91-8584-4732-bfd1-a26cacead517} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 560, line 561) (in query: SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL);) 2025.06.13 15:56:59.269540 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:59.308629 [ 45013 ] {1da03b3e-ef94-4a97-820c-0f6f55525674} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 561, line 562) (in query: SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL);) 2025.06.13 15:56:59.316084 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:59.423002 [ 45013 ] {f4026306-cd62-426b-a33f-b32603a18b4e} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 562, line 563) (in query: SELECT firstValueRespectNulls(NULL, NULL, NULL);) 2025.06.13 15:56:59.431026 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:59.672495 [ 45013 ] {9db3cd2a-9b5f-4595-b38c-f14d4aa6b0d3} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 564, line 565) (in query: SELECT first_value_respect_nulls(NULL, NULL, NULL);) 2025.06.13 15:56:59.680554 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:59.739600 [ 45013 ] {5ec4c200-9e92-4ebe-9ba8-a508436c2fd0} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 565, line 566) (in query: SELECT flameGraph(NULL, NULL, NULL);) 2025.06.13 15:56:59.745335 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:56:59.841392 [ 45013 ] {d4551b9e-4598-409e-b89c-9246b4632af2} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 566, line 567) (in query: SELECT flatten(NULL, NULL, NULL);) 2025.06.13 15:56:59.931736 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:56:59.991425 [ 45013 ] {5af89196-ce3d-4cfa-84f8-176da1e4e633} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 567, line 568) (in query: SELECT flattenTuple(NULL, NULL, NULL);) 2025.06.13 15:57:00.003092 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:00.475831 [ 45013 ] {3cce6b62-eb61-48de-8832-6aef075275c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 572, line 573) (in query: SELECT formatQuery(NULL, NULL, NULL);) 2025.06.13 15:57:00.527129 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:00.564356 [ 45013 ] {a98997c9-dfb7-4b2c-ab65-98d0f3f3966d} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 573, line 574) (in query: SELECT formatQueryOrNull(NULL, NULL, NULL);) 2025.06.13 15:57:00.573441 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:00.676573 [ 45013 ] {ff82bee5-04f3-45a4-919f-4f13241b078b} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 574, line 575) (in query: SELECT formatQuerySingleLine(NULL, NULL, NULL);) 2025.06.13 15:57:00.683340 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:00.753434 [ 45013 ] {f7e293c3-7b7f-417b-beba-13aa19fece9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 575, line 576) (in query: SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL);) 2025.06.13 15:57:00.759468 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:00.792143 [ 45013 ] {86a310bc-e66b-476c-a96e-8acf5ecf42a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 576, line 577) (in query: SELECT formatReadableDecimalSize(NULL, NULL, NULL);) 2025.06.13 15:57:00.798063 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:00.823675 [ 45013 ] {b00696c6-eeef-4248-a7a5-553c28a528df} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 577, line 578) (in query: SELECT formatReadableQuantity(NULL, NULL, NULL);) 2025.06.13 15:57:00.829118 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:00.867242 [ 45013 ] {9daed535-a3a4-4041-b77e-0830e6feecae} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 578, line 579) (in query: SELECT formatReadableSize(NULL, NULL, NULL);) 2025.06.13 15:57:00.872017 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:01.048491 [ 45013 ] {5207362e-6fe0-4660-b2a2-98e818b63d2d} executeQuery: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 580, line 581) (in query: SELECT formatRow(NULL, NULL, NULL);) 2025.06.13 15:57:01.055828 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:01.098012 [ 45013 ] {e909f127-5041-453a-a849-de964de57aa3} executeQuery: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 581, line 582) (in query: SELECT formatRowNoNewline(NULL, NULL, NULL);) 2025.06.13 15:57:01.105712 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:01.143317 [ 45013 ] {e6821908-c85b-461d-811f-ccf456ee1640} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 582, line 583) (in query: SELECT fragment(NULL, NULL, NULL);) 2025.06.13 15:57:01.149451 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:01.247427 [ 45013 ] {3d8cf19d-4385-418c-acf6-eb8ee894378f} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 583, line 584) (in query: SELECT fromDaysSinceYearZero(NULL, NULL, NULL);) 2025.06.13 15:57:01.255981 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:01.344218 [ 45013 ] {e319b548-4246-4ecc-85f5-ae54c3a7f589} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 584, line 585) (in query: SELECT fromDaysSinceYearZero32(NULL, NULL, NULL);) 2025.06.13 15:57:01.350282 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:01.399476 [ 45013 ] {49f979ed-8f1a-431a-8111-45ea4f3b879b} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 585, line 586) (in query: SELECT fromModifiedJulianDay(NULL, NULL, NULL);) 2025.06.13 15:57:01.404479 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:01.482952 [ 45013 ] {ca71aec8-f9f3-4e86-8824-4f64459d4f00} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 586, line 587) (in query: SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL);) 2025.06.13 15:57:01.487967 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:01.523454 [ 45013 ] {916fea9f-5233-4bf6-bc6b-6693eb549e3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 587, line 588) (in query: SELECT fromUTCTimestamp(NULL, NULL, NULL);) 2025.06.13 15:57:01.529743 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:02.110100 [ 18510 ] {3221e03c-4273-4891-bfd6-3af3d9e157ec} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1007, line 336) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:02.118368 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:02.220322 [ 45013 ] {92ef5c71-a111-4dc9-9e53-0a08039d1a74} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 594, line 595) (in query: SELECT from_utc_timestamp(NULL, NULL, NULL);) 2025.06.13 15:57:02.226200 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:02.261147 [ 45013 ] {b264d8f2-e0f0-43bb-88f1-ce50a7152b6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 595, line 596) (in query: SELECT fullHostName(NULL, NULL, NULL);) 2025.06.13 15:57:02.267844 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:02.314880 [ 45013 ] {2e2d6fe1-3f4a-4f11-81a0-f334d4658646} executeQuery: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 596, line 597) (in query: SELECT fuzzBits(NULL, NULL, NULL);) 2025.06.13 15:57:02.320601 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:02.477929 [ 45013 ] {b821c5a1-6352-46bd-a2a8-56a017c12355} executeQuery: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 598, line 599) (in query: SELECT gcd(NULL, NULL, NULL);) 2025.06.13 15:57:02.485863 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:02.525910 [ 45013 ] {355a34c1-2116-47e1-b3b0-b6ef0a55b3fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 599, line 600) (in query: SELECT generateRandomStructure(NULL, NULL, NULL);) 2025.06.13 15:57:02.534604 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:02.663151 [ 45013 ] {f9b0ae89-9e62-4bfd-aa5c-92b9617a5f78} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 3, should be 1: In scope SELECT generateSerialID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 600, line 601) (in query: SELECT generateSerialID(NULL, NULL, NULL);) 2025.06.13 15:57:02.669964 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 3, should be 1: In scope SELECT generateSerialID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:02.708427 [ 45013 ] {517c373a-e4e7-448d-8113-9fa107591370} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 601, line 602) (in query: SELECT generateSnowflakeID(NULL, NULL, NULL);) 2025.06.13 15:57:02.715998 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:02.818079 [ 18510 ] {5ac64d37-22e1-4360-a7e7-fe8b15f24e23} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1013, line 338) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:02.855509 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:03.006346 [ 45013 ] {cb6e71fa-3d31-44bf-a1d8-3491794a86a9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 603, line 604) (in query: SELECT generateUUIDv4(NULL, NULL, NULL);) 2025.06.13 15:57:03.021054 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:03.070324 [ 45013 ] {4eceeeb1-f99c-488a-9514-b84b8b66ceb9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 604, line 605) (in query: SELECT generateUUIDv7(NULL, NULL, NULL);) 2025.06.13 15:57:03.077200 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:03.114987 [ 45013 ] {0ee5e797-1a8e-4a84-982c-a8c9cfb8b3b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 605, line 606) (in query: SELECT geoDistance(NULL, NULL, NULL);) 2025.06.13 15:57:03.123619 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:03.333290 [ 45013 ] {396a2992-b9df-4796-ba32-310c14436a96} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 607, line 608) (in query: SELECT geoToS2(NULL, NULL, NULL);) 2025.06.13 15:57:03.342547 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:03.404923 [ 45013 ] {0891718b-fef0-481c-8917-23e4b0dd3a79} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 608, line 609) (in query: SELECT geohashDecode(NULL, NULL, NULL);) 2025.06.13 15:57:03.417459 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:03.547565 [ 45013 ] {3f32787e-7c4e-4ddf-8b08-26781bcf6922} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 610, line 611) (in query: SELECT geohashesInBox(NULL, NULL, NULL);) 2025.06.13 15:57:03.554261 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:03.595075 [ 45013 ] {fdf1fc28-d972-4457-aeb8-4d38c4a0344d} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 611, line 612) (in query: SELECT getClientHTTPHeader(NULL, NULL, NULL);) 2025.06.13 15:57:03.602251 [ 45013 ] {} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.06.13 15:57:03.642201 [ 45013 ] {5ce84be0-e297-4221-82d2-d430afb19667} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 612, line 613) (in query: SELECT getMacro(NULL, NULL, NULL);) 2025.06.13 15:57:03.648403 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:03.685425 [ 45013 ] {5aa0344f-6220-4677-bb1a-05f7a0e92feb} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 3, should be 1: In scope SELECT getMaxTableNameLengthForDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 613, line 614) (in query: SELECT getMaxTableNameLengthForDatabase(NULL, NULL, NULL);) 2025.06.13 15:57:03.691919 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 3, should be 1: In scope SELECT getMaxTableNameLengthForDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:03.740832 [ 45013 ] {aea66667-b978-4847-bd33-bd1c63354acb} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 614, line 615) (in query: SELECT getOSKernelVersion(NULL, NULL, NULL);) 2025.06.13 15:57:03.749384 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:03.776669 [ 45013 ] {e3b7718a-db4a-42b5-94a1-cfb72999685a} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 615, line 616) (in query: SELECT getServerPort(NULL, NULL, NULL);) 2025.06.13 15:57:03.783289 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:03.809680 [ 45013 ] {93cf5254-5945-47ab-af56-499e3df5ae4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 616, line 617) (in query: SELECT getSetting(NULL, NULL, NULL);) 2025.06.13 15:57:03.815540 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:03.916156 [ 45013 ] {240a09cb-1bea-453f-b04e-e92068651419} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 3, should be 2: In scope SELECT getSettingOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 617, line 618) (in query: SELECT getSettingOrDefault(NULL, NULL, NULL);) 2025.06.13 15:57:03.924355 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 3, should be 2: In scope SELECT getSettingOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:03.962606 [ 45013 ] {d35f8e14-b336-4860-9f5f-07f93281f5d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 618, line 619) (in query: SELECT getSizeOfEnumType(NULL, NULL, NULL);) 2025.06.13 15:57:03.971086 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:04.072141 [ 45013 ] {7234b366-f21e-416d-ba3e-1c318ead5d64} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 619, line 620) (in query: SELECT getSubcolumn(NULL, NULL, NULL);) 2025.06.13 15:57:04.078110 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:04.111493 [ 45013 ] {82530936-4099-4233-a966-206ee2fe4a63} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 620, line 621) (in query: SELECT getTypeSerializationStreams(NULL, NULL, NULL);) 2025.06.13 15:57:04.117446 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:04.150518 [ 45013 ] {11ec13c3-888f-4aa6-bfed-29e0d300c338} executeQuery: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 621, line 622) (in query: SELECT globalIn(NULL, NULL, NULL);) 2025.06.13 15:57:04.156396 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:04.221088 [ 45013 ] {d244524f-b0b2-432c-ae44-957f14896122} executeQuery: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 622, line 623) (in query: SELECT globalInIgnoreSet(NULL, NULL, NULL);) 2025.06.13 15:57:04.228189 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:04.270109 [ 45013 ] {18b90e24-88bf-4fa5-838a-548943dde612} executeQuery: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 623, line 624) (in query: SELECT globalNotIn(NULL, NULL, NULL);) 2025.06.13 15:57:04.277248 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:04.371153 [ 45013 ] {0207c3fd-54f0-454f-8428-e5f9042cad26} executeQuery: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 624, line 625) (in query: SELECT globalNotInIgnoreSet(NULL, NULL, NULL);) 2025.06.13 15:57:04.379034 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:04.413904 [ 45013 ] {da6f7793-b746-45dd-8459-7fa8873a5216} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 625, line 626) (in query: SELECT globalNotNullIn(NULL, NULL, NULL);) 2025.06.13 15:57:04.422661 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:04.466140 [ 45013 ] {e0b47861-130f-42a0-bdea-b6681207dec8} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 626, line 627) (in query: SELECT globalNotNullInIgnoreSet(NULL, NULL, NULL);) 2025.06.13 15:57:04.474065 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:04.528715 [ 45013 ] {f8b0b01e-aaa6-425c-b5bd-d8bdc63366fa} executeQuery: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 627, line 628) (in query: SELECT globalNullIn(NULL, NULL, NULL);) 2025.06.13 15:57:04.535660 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:04.572607 [ 45013 ] {7fe4628c-047a-434a-b5b7-162a84d45d4e} executeQuery: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 628, line 629) (in query: SELECT globalNullInIgnoreSet(NULL, NULL, NULL);) 2025.06.13 15:57:04.579480 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:04.698141 [ 45013 ] {c4e18270-31aa-4e33-b67a-2287d3cdcd66} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 629, line 630) (in query: SELECT globalVariable(NULL, NULL, NULL);) 2025.06.13 15:57:04.706130 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:04.820094 [ 45013 ] {9b7f3f0c-984b-4d12-ace5-adf05fdf5be4} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 630, line 631) (in query: SELECT greatCircleAngle(NULL, NULL, NULL);) 2025.06.13 15:57:04.857215 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:04.911652 [ 45013 ] {3679c424-958d-4e88-afda-cd04e5146545} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 631, line 632) (in query: SELECT greatCircleDistance(NULL, NULL, NULL);) 2025.06.13 15:57:04.918523 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:04.970560 [ 45013 ] {8ca47536-3baa-4433-89eb-ab867350b146} executeQuery: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 632, line 633) (in query: SELECT greater(NULL, NULL, NULL);) 2025.06.13 15:57:05.008390 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:05.055637 [ 45013 ] {5bec4b9d-184a-4169-bc68-ee41c868ba0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 633, line 634) (in query: SELECT greaterOrEquals(NULL, NULL, NULL);) 2025.06.13 15:57:05.069015 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:06.549874 [ 18510 ] {60f78b3e-d1eb-4dcb-a90c-0a6bbe6a6367} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1037, line 346) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:06.558251 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:07.165723 [ 18510 ] {238da952-9756-4f5b-91f0-d7b82c9c833c} 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.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1041, line 347) (in query: INSERT INTO mt_00763_2 SELECT toString(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:57:07.176060 [ 18510 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:57:07.738758 [ 45013 ] {68de72c6-3595-447e-a06e-700b37417104} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 653, line 654) (in query: SELECT h3CellAreaM2(NULL, NULL, NULL);) 2025.06.13 15:57:07.760171 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:07.855474 [ 45013 ] {cd78f276-f0fd-4c75-ab94-fa026bee4a47} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 654, line 655) (in query: SELECT h3CellAreaRads2(NULL, NULL, NULL);) 2025.06.13 15:57:07.863405 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:07.946019 [ 45013 ] {16c3252d-1710-4aa4-80b5-8a3e79f74f25} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 655, line 656) (in query: SELECT h3Distance(NULL, NULL, NULL);) 2025.06.13 15:57:07.958784 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:08.074083 [ 45013 ] {4351a75f-a00f-4686-a161-75425ae02882} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 656, line 657) (in query: SELECT h3EdgeAngle(NULL, NULL, NULL);) 2025.06.13 15:57:08.094749 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:08.247933 [ 45013 ] {81bf6cf3-fa36-402e-bd79-1611d8435d0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 657, line 658) (in query: SELECT h3EdgeLengthKm(NULL, NULL, NULL);) 2025.06.13 15:57:08.256273 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:08.421480 [ 45013 ] {e3ea173e-84ee-4c86-bc88-9a1b011b0d24} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 658, line 659) (in query: SELECT h3EdgeLengthM(NULL, NULL, NULL);) 2025.06.13 15:57:08.436597 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:08.466976 [ 45013 ] {ceef2693-f39b-4db8-a59f-8b03a8b3c2ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 659, line 660) (in query: SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL);) 2025.06.13 15:57:08.473274 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:08.527487 [ 45013 ] {b292764f-e730-402b-996d-94af809844bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 660, line 661) (in query: SELECT h3ExactEdgeLengthM(NULL, NULL, NULL);) 2025.06.13 15:57:08.535676 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:08.653141 [ 45013 ] {1dae6451-0eb3-4c08-b96b-00bc9cc53553} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 661, line 662) (in query: SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL);) 2025.06.13 15:57:08.659625 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:08.689938 [ 45013 ] {af4d0a7e-fbf6-4e71-9824-61e531bbef4c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 662, line 663) (in query: SELECT h3GetBaseCell(NULL, NULL, NULL);) 2025.06.13 15:57:08.696853 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:08.727695 [ 45013 ] {e9b333fc-8286-4eac-9487-3dbf9dae7c76} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 663, line 664) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.06.13 15:57:08.736276 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:08.769952 [ 45013 ] {2e48c504-5256-4557-bf30-f8579ab6ebdd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 664, line 665) (in query: SELECT h3GetFaces(NULL, NULL, NULL);) 2025.06.13 15:57:08.777542 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:08.850665 [ 45013 ] {4ba1ce1d-e608-4e5f-bf69-7f2e9b0a3e75} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 665, line 666) (in query: SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.06.13 15:57:08.858182 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:08.914544 [ 45013 ] {9cbdfa0a-b02d-4ba4-9674-e3fd853dbd96} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 666, line 667) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.06.13 15:57:08.920253 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.035507 [ 45013 ] {e2d0c5f1-b45c-477b-8547-99de28bde58e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 667, line 668) (in query: SELECT h3GetPentagonIndexes(NULL, NULL, NULL);) 2025.06.13 15:57:09.044148 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.092759 [ 45013 ] {4f02f76b-24a7-4e9e-9b1e-9a79c9aeeea7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 668, line 669) (in query: SELECT h3GetRes0Indexes(NULL, NULL, NULL);) 2025.06.13 15:57:09.099582 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.180566 [ 18510 ] {354de8b0-a8f8-4e1e-91c4-04aa58d31a10} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1055, line 352) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:09.187226 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:09.205284 [ 45013 ] {3a8fe101-56e9-4a64-bffd-e43b1af8afc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 669, line 670) (in query: SELECT h3GetResolution(NULL, NULL, NULL);) 2025.06.13 15:57:09.212505 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.251923 [ 45013 ] {ff223fea-7b82-4efb-a18d-1c8b10a89ad5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 670, line 671) (in query: SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL);) 2025.06.13 15:57:09.259144 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.292058 [ 45013 ] {1e7fd56b-0d69-46a4-829c-f8023c5fb9f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 671, line 672) (in query: SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL);) 2025.06.13 15:57:09.298019 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.354662 [ 45013 ] {ac915a71-43a9-462f-bd3c-38f65fe85bed} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 672, line 673) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL);) 2025.06.13 15:57:09.361449 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.395148 [ 45013 ] {ce4d5c82-7034-4ebf-bb8c-c611c3bd630a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 673, line 674) (in query: SELECT h3HexAreaKm2(NULL, NULL, NULL);) 2025.06.13 15:57:09.405118 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.440302 [ 45013 ] {ed9010d3-852c-4d04-8079-4c81d84731ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 674, line 675) (in query: SELECT h3HexAreaM2(NULL, NULL, NULL);) 2025.06.13 15:57:09.447320 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.480369 [ 45013 ] {da56139b-6bb1-4972-a1dc-81005251429d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 675, line 676) (in query: SELECT h3HexRing(NULL, NULL, NULL);) 2025.06.13 15:57:09.486124 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.520528 [ 45013 ] {c8a21463-08e8-4c64-91c2-fb2fc6229de0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 676, line 677) (in query: SELECT h3IndexesAreNeighbors(NULL, NULL, NULL);) 2025.06.13 15:57:09.526954 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.634400 [ 45013 ] {47352184-a841-4372-889c-17628a525b51} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 677, line 678) (in query: SELECT h3IsPentagon(NULL, NULL, NULL);) 2025.06.13 15:57:09.639807 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.739285 [ 45013 ] {3872866e-c811-4b16-bf89-980d02cd0326} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 678, line 679) (in query: SELECT h3IsResClassIII(NULL, NULL, NULL);) 2025.06.13 15:57:09.744781 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.781267 [ 45013 ] {a7eb77b6-819e-4606-a426-af5140f0d5b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 679, line 680) (in query: SELECT h3IsValid(NULL, NULL, NULL);) 2025.06.13 15:57:09.787769 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.921519 [ 45013 ] {dc9d6ae5-d802-41bc-8483-22e023430bc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 680, line 681) (in query: SELECT h3Line(NULL, NULL, NULL);) 2025.06.13 15:57:09.930565 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:09.964462 [ 45013 ] {a4beadfc-230f-45bf-9a8a-caa21f932942} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 681, line 682) (in query: SELECT h3NumHexagons(NULL, NULL, NULL);) 2025.06.13 15:57:09.971964 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:10.004868 [ 45013 ] {8e855b92-ce43-4d60-919b-0f5226098d04} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 682, line 683) (in query: SELECT h3PointDistKm(NULL, NULL, NULL);) 2025.06.13 15:57:10.011159 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:10.040946 [ 45013 ] {abd6cccf-f994-4b12-9bde-a4b46822236e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 683, line 684) (in query: SELECT h3PointDistM(NULL, NULL, NULL);) 2025.06.13 15:57:10.047377 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:10.127170 [ 45013 ] {c1ace1ad-a3b4-4116-81cf-e161431ce2c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 684, line 685) (in query: SELECT h3PointDistRads(NULL, NULL, NULL);) 2025.06.13 15:57:10.133927 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:10.229337 [ 45013 ] {8d395c19-5f79-43e6-a5dd-8b1d31c14c41} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 685, line 686) (in query: SELECT h3ToCenterChild(NULL, NULL, NULL);) 2025.06.13 15:57:10.235293 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:10.269315 [ 45013 ] {bd9a0751-0714-4c6e-bd75-023b65363385} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 686, line 687) (in query: SELECT h3ToChildren(NULL, NULL, NULL);) 2025.06.13 15:57:10.276398 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:10.311064 [ 45013 ] {384b5a15-f714-45b9-9cbd-8e8051eb02ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 687, line 688) (in query: SELECT h3ToGeo(NULL, NULL, NULL);) 2025.06.13 15:57:10.317730 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:10.350825 [ 45013 ] {31c7d31e-de56-4050-a05f-8b82b0d0adee} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 688, line 689) (in query: SELECT h3ToGeoBoundary(NULL, NULL, NULL);) 2025.06.13 15:57:10.357336 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:10.388579 [ 45013 ] {0c1a9e78-fcd8-4e1c-91f8-3dff7ffea515} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 689, line 690) (in query: SELECT h3ToParent(NULL, NULL, NULL);) 2025.06.13 15:57:10.482758 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:10.519159 [ 45013 ] {ad285a64-9278-4927-9540-e6d270def817} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 690, line 691) (in query: SELECT h3ToString(NULL, NULL, NULL);) 2025.06.13 15:57:10.526944 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:10.562823 [ 45013 ] {f9f79f6d-0d3a-4862-9e26-3e5223e9e8f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 691, line 692) (in query: SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL);) 2025.06.13 15:57:10.570514 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:10.709962 [ 45013 ] {2bf45819-bbf7-40d4-86bb-e61ccfb69f6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 692, line 693) (in query: SELECT h3kRing(NULL, NULL, NULL);) 2025.06.13 15:57:10.718308 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:10.949439 [ 45013 ] {4b368ae1-0b44-4251-b43b-705351c958b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 694, line 695) (in query: SELECT has(NULL, NULL, NULL);) 2025.06.13 15:57:10.955648 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:10.995238 [ 45013 ] {3b1bd2e9-d83b-4dcd-9228-f1fb69f7ec46} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 695, line 696) (in query: SELECT hasAll(NULL, NULL, NULL);) 2025.06.13 15:57:11.008410 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:11.045163 [ 45013 ] {e4289ccc-7c29-48c0-b2ff-9327be88a7f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 696, line 697) (in query: SELECT hasAny(NULL, NULL, NULL);) 2025.06.13 15:57:11.053488 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:11.245106 [ 45013 ] {eceb0dc6-a68d-4848-b9d3-06cd8ab6fdeb} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 698, line 699) (in query: SELECT hasSubsequence(NULL, NULL, NULL);) 2025.06.13 15:57:11.251426 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:11.297723 [ 45013 ] {51454fce-9ce1-4d86-959e-efb9c71904df} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 699, line 700) (in query: SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL);) 2025.06.13 15:57:11.305077 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:11.464400 [ 45013 ] {fd2c97fd-1c1b-49df-944a-7a4b1fd947ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 700, line 701) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:11.472155 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:11.520234 [ 45013 ] {1e6e1345-88a4-418d-b41c-82020967eea3} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 701, line 702) (in query: SELECT hasSubsequenceUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:11.533835 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:11.577984 [ 45013 ] {4b2cddaa-6a42-4c69-a29f-89f03529a699} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 702, line 703) (in query: SELECT hasSubstr(NULL, NULL, NULL);) 2025.06.13 15:57:11.586897 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:11.622748 [ 45013 ] {a9612342-0306-4969-9fff-3d716dc524eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 703, line 704) (in query: SELECT hasThreadFuzzer(NULL, NULL, NULL);) 2025.06.13 15:57:11.652345 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:11.688964 [ 45013 ] {691c37b0-9f2a-4aeb-b5f8-aa77c29843f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 704, line 705) (in query: SELECT hasToken(NULL, NULL, NULL);) 2025.06.13 15:57:11.696238 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:11.865255 [ 45013 ] {8e83ad1d-92a1-4cfd-bb8c-61f8254e7500} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 705, line 706) (in query: SELECT hasTokenCaseInsensitive(NULL, NULL, NULL);) 2025.06.13 15:57:11.871565 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:11.945168 [ 45013 ] {526a959c-8bdc-4b68-99e4-c44469af898c} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 706, line 707) (in query: SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL);) 2025.06.13 15:57:11.963203 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:12.023091 [ 45013 ] {e98772cf-c1ee-4fc4-9cff-a8cbff787fcc} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 707, line 708) (in query: SELECT hasTokenOrNull(NULL, NULL, NULL);) 2025.06.13 15:57:12.034062 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:12.096685 [ 45013 ] {a4ad17b6-671d-4ec9-9330-78568c42cace} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 708, line 709) (in query: SELECT hex(NULL, NULL, NULL);) 2025.06.13 15:57:12.105412 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:12.137789 [ 45013 ] {21a9b4f6-c18f-4f20-84b5-80fc279df6e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 709, line 710) (in query: SELECT hilbertDecode(NULL, NULL, NULL);) 2025.06.13 15:57:12.150586 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:13.147154 [ 45013 ] {6808f23e-015a-46d4-add0-535f76f46e49} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 716, line 717) (in query: SELECT hostName(NULL, NULL, NULL);) 2025.06.13 15:57:13.154545 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:13.182949 [ 18510 ] {a4e64706-0924-47b5-881d-5e7cb4a8cb70} 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.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1080, line 360) (in query: INSERT INTO mt_00763_2 SELECT toString(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:57:13.196266 [ 18510 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:57:13.198312 [ 45013 ] {1a848cd9-2c98-40a7-82af-2e20bd143ada} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 717, line 718) (in query: SELECT hostname(NULL, NULL, NULL);) 2025.06.13 15:57:13.217067 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:13.321765 [ 45013 ] {bd17522c-1622-4de0-8545-0454ee3ee241} executeQuery: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 718, line 719) (in query: SELECT hypot(NULL, NULL, NULL);) 2025.06.13 15:57:13.349955 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:13.490462 [ 45013 ] {8608458d-fecd-4e2e-8c6a-feb80b65c7a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergBucket doesn't match: passed 3, should be 2: In scope SELECT icebergBucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 719, line 720) (in query: SELECT icebergBucket(NULL, NULL, NULL);) 2025.06.13 15:57:13.497365 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergBucket doesn't match: passed 3, should be 2: In scope SELECT icebergBucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:13.538892 [ 45013 ] {60bdf6f2-d8b0-49ce-874c-a3353af0ec21} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergHash doesn't match: passed 3, should be 1: In scope SELECT icebergHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 720, line 721) (in query: SELECT icebergHash(NULL, NULL, NULL);) 2025.06.13 15:57:13.546345 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergHash doesn't match: passed 3, should be 1: In scope SELECT icebergHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:13.628771 [ 45013 ] {15f98a29-82a8-4182-8641-b0ba2981dfa9} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 3, should be 2: In scope SELECT icebergTruncate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 721, line 722) (in query: SELECT icebergTruncate(NULL, NULL, NULL);) 2025.06.13 15:57:13.659825 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 3, should be 2: In scope SELECT icebergTruncate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:13.781624 [ 45013 ] {4700afff-15ab-4f7b-86c7-81aeefe30e2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 722, line 723) (in query: SELECT identity(NULL, NULL, NULL);) 2025.06.13 15:57:13.791631 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:13.857768 [ 45013 ] {dd7b6366-f6b8-4a1c-a4f5-e5c410c6f277} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 723, line 724) (in query: SELECT idnaDecode(NULL, NULL, NULL);) 2025.06.13 15:57:13.866279 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:14.003570 [ 45013 ] {178cae47-5086-4dfd-bcb2-197fe5f4033b} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 724, line 725) (in query: SELECT idnaEncode(NULL, NULL, NULL);) 2025.06.13 15:57:14.010395 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:14.207590 [ 45013 ] {8ea95538-ba91-4970-9d07-7d0b477c1d46} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 726, line 727) (in query: SELECT ifNotFinite(NULL, NULL, NULL);) 2025.06.13 15:57:14.214592 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:14.375548 [ 45013 ] {44b43b94-3304-47a5-aa88-fa6954583597} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 727, line 728) (in query: SELECT ifNull(NULL, NULL, NULL);) 2025.06.13 15:57:14.382615 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:14.511003 [ 45013 ] {924c9edc-ea8b-429f-871d-d647f702ad3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 729, line 730) (in query: SELECT ilike(NULL, NULL, NULL);) 2025.06.13 15:57:14.517876 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:14.545344 [ 45013 ] {3207a131-29e2-4fad-a4d7-eeb4fbf9cfd9} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 730, line 731) (in query: SELECT in(NULL, NULL, NULL);) 2025.06.13 15:57:14.551843 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:14.579519 [ 45013 ] {4b87eb24-d0a4-460d-a3bc-08e624791ffe} executeQuery: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 731, line 732) (in query: SELECT inIgnoreSet(NULL, NULL, NULL);) 2025.06.13 15:57:14.585800 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:14.683747 [ 45013 ] {7b278d3d-3148-44d9-99a4-f8704b4bfa48} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 733, line 734) (in query: SELECT indexOf(NULL, NULL, NULL);) 2025.06.13 15:57:14.690629 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:14.727151 [ 45013 ] {9db240d6-e982-49b1-b380-e9393d35fc12} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 3, should be 2: In scope SELECT indexOfAssumeSorted(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 734, line 735) (in query: SELECT indexOfAssumeSorted(NULL, NULL, NULL);) 2025.06.13 15:57:14.733329 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 3, should be 2: In scope SELECT indexOfAssumeSorted(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:14.762246 [ 45013 ] {5a31edf8-c202-47b2-bc08-44e59f2d869b} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 735, line 736) (in query: SELECT initcap(NULL, NULL, NULL);) 2025.06.13 15:57:14.769017 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:14.803648 [ 45013 ] {93f94567-8d8e-41fe-8385-931edf0a5fdf} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 736, line 737) (in query: SELECT initcapUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:14.810427 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:14.858032 [ 45013 ] {5eebb7f2-e320-4be5-a854-a44d79d69439} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 737, line 738) (in query: SELECT initialQueryID(NULL, NULL, NULL);) 2025.06.13 15:57:14.865077 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:14.925239 [ 45013 ] {86369e57-7d66-41a2-8cb5-142a070be2d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initialQueryStartTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 738, line 739) (in query: SELECT initialQueryStartTime(NULL, NULL, NULL);) 2025.06.13 15:57:14.934742 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initialQueryStartTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:14.990560 [ 45013 ] {e210db80-86a5-4435-af99-5bc3a0ed5cca} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 739, line 740) (in query: SELECT initial_query_id(NULL, NULL, NULL);) 2025.06.13 15:57:15.004900 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:15.066959 [ 45013 ] {c53c0c55-e646-40d1-abb0-3154540b2e5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initial_query_start_time(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 740, line 741) (in query: SELECT initial_query_start_time(NULL, NULL, NULL);) 2025.06.13 15:57:15.073385 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initial_query_start_time(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:15.197450 [ 45013 ] {12d9d3d4-e984-474d-8574-dbab12cbae51} executeQuery: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 741, line 742) (in query: SELECT initializeAggregation(NULL, NULL, NULL);) 2025.06.13 15:57:15.217287 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:15.415835 [ 45013 ] {7f9a2c23-04dd-4211-b147-89cc8ad4f438} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 743, line 744) (in query: SELECT intDiv(NULL, NULL, NULL);) 2025.06.13 15:57:15.447125 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:15.493714 [ 45013 ] {720c24c4-6e0e-4943-9564-8d50c888f17a} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 744, line 745) (in query: SELECT intDivOrZero(NULL, NULL, NULL);) 2025.06.13 15:57:15.501797 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:15.545119 [ 45013 ] {d22a0323-04cd-4b06-8b17-9fdfb97f96ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 745, line 746) (in query: SELECT intExp10(NULL, NULL, NULL);) 2025.06.13 15:57:15.549546 [ 18510 ] {c2015f4c-8712-4c8a-be91-e135521b3b2f} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1094, line 365) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:15.552650 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:15.558745 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:15.598720 [ 45013 ] {4b80fdbf-ef8c-4006-bdb8-fa94dbea7bce} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 746, line 747) (in query: SELECT intExp2(NULL, NULL, NULL);) 2025.06.13 15:57:15.605836 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:15.658033 [ 45013 ] {d9b30dde-993c-487a-922f-9eac35b12253} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 747, line 748) (in query: SELECT intHash32(NULL, NULL, NULL);) 2025.06.13 15:57:15.665718 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:15.909188 [ 45013 ] {e4435c02-e6f6-4172-bf5b-10aac18d0d11} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 748, line 749) (in query: SELECT intHash64(NULL, NULL, NULL);) 2025.06.13 15:57:15.915334 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:16.042666 [ 45013 ] {663f3cf7-3220-4d1e-8663-f44da63fb801} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 750, line 751) (in query: SELECT isConstant(NULL, NULL, NULL);) 2025.06.13 15:57:16.076148 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:16.209916 [ 45013 ] {57f62a7f-07fb-42be-bda0-9cfa5f852ce4} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 752, line 753) (in query: SELECT isDynamicElementInSharedData(NULL, NULL, NULL);) 2025.06.13 15:57:16.224479 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:16.263102 [ 45013 ] {f7f18995-f652-49b0-ba80-3e32d3654d39} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 753, line 754) (in query: SELECT isFinite(NULL, NULL, NULL);) 2025.06.13 15:57:16.270026 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:16.312470 [ 45013 ] {e39e289c-edc7-4d48-b656-81854e5bd1cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 754, line 755) (in query: SELECT isIPAddressInRange(NULL, NULL, NULL);) 2025.06.13 15:57:16.326513 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:16.390763 [ 45013 ] {43d3c572-2fe6-4433-bfdf-3a48e81e0b6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 755, line 756) (in query: SELECT isIPv4String(NULL, NULL, NULL);) 2025.06.13 15:57:16.408086 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:16.437407 [ 18510 ] {7a3b830c-905e-4190-a86d-9606836609f2} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1100, line 367) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:16.449408 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:16.451925 [ 45013 ] {387ba5bf-d261-43a9-bc77-675baed69ed6} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 756, line 757) (in query: SELECT isIPv6String(NULL, NULL, NULL);) 2025.06.13 15:57:16.457491 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:16.497026 [ 45013 ] {f4abf1a8-ee61-4c0c-a66e-c954cb9c37dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 757, line 758) (in query: SELECT isInfinite(NULL, NULL, NULL);) 2025.06.13 15:57:16.503546 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:16.729946 [ 18510 ] {f7381491-57c2-4a6f-bbbe-31de3b97c2e2} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1103, line 368) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:16.738216 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:16.738647 [ 45013 ] {370af3ab-c158-4779-a4fd-75ab4680ce9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 758, line 759) (in query: SELECT isNaN(NULL, NULL, NULL);) 2025.06.13 15:57:16.745092 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:16.778471 [ 45013 ] {ee117d9a-501e-48da-90ff-8489cb0ec19d} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 759, line 760) (in query: SELECT isNotDistinctFrom(NULL, NULL, NULL);) 2025.06.13 15:57:16.783992 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:16.899424 [ 45013 ] {c4fd6213-8d76-40e6-8638-f5cb2598917e} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 760, line 761) (in query: SELECT isNotNull(NULL, NULL, NULL);) 2025.06.13 15:57:16.908230 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:16.972579 [ 45013 ] {18cb81ff-ebfb-4404-9479-0956f5f68c39} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 761, line 762) (in query: SELECT isNull(NULL, NULL, NULL);) 2025.06.13 15:57:16.992661 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:17.128012 [ 45013 ] {bc44a391-7579-4b10-9aa3-7903d384ff59} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 762, line 763) (in query: SELECT isNullable(NULL, NULL, NULL);) 2025.06.13 15:57:17.136074 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:17.181633 [ 45013 ] {c5bba885-0ec2-488c-adea-c30caf9880b4} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 763, line 764) (in query: SELECT isValidJSON(NULL, NULL, NULL);) 2025.06.13 15:57:17.188968 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:17.261594 [ 45013 ] {73189b69-0267-4301-bd2c-4dce014e36fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 764, line 765) (in query: SELECT isValidUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:17.269334 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:17.299140 [ 45013 ] {8ad46ca9-bd16-4ec8-a7f0-2afeb3744879} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 765, line 766) (in query: SELECT isZeroOrNull(NULL, NULL, NULL);) 2025.06.13 15:57:17.307095 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:17.384517 [ 45013 ] {3fba4c3b-5fe2-4220-a7fc-cd60dacc9dd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 766, line 767) (in query: SELECT jaroSimilarity(NULL, NULL, NULL);) 2025.06.13 15:57:17.394568 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:17.672223 [ 45013 ] {f3e207e4-e71b-4b19-aaec-21dde024d3b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 767, line 768) (in query: SELECT jaroWinklerSimilarity(NULL, NULL, NULL);) 2025.06.13 15:57:17.678585 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:17.696293 [ 18510 ] {67e54245-a65e-4c24-b9a8-cb24da9d8501} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1109, line 370) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:17.705507 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:17.909512 [ 45013 ] {6840e61e-e6d3-458d-9e04-eb54cd626297} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 770, line 771) (in query: SELECT joinGet(NULL, NULL, NULL);) 2025.06.13 15:57:17.916590 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:17.938736 [ 18510 ] {cda80d89-5029-426b-bb8d-b9a43a444b5e} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1112, line 371) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:17.945831 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:17.949515 [ 45013 ] {4ea49c48-6d1a-4534-bea8-c2ed7057334c} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 771, line 772) (in query: SELECT joinGetOrNull(NULL, NULL, NULL);) 2025.06.13 15:57:17.999930 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:18.166503 [ 45013 ] {02f1b4a5-862d-4a2d-b162-e72520f7a20f} executeQuery: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 773, line 774) (in query: SELECT jumpConsistentHash(NULL, NULL, NULL);) 2025.06.13 15:57:18.173299 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:18.286018 [ 45013 ] {6565e376-a38c-4097-a9f7-8d0686010fab} executeQuery: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 3, should be 1: In scope SELECT keccak256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 775, line 776) (in query: SELECT keccak256(NULL, NULL, NULL);) 2025.06.13 15:57:18.292535 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 3, should be 1: In scope SELECT keccak256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:18.480165 [ 45013 ] {2b51f94d-7f45-4903-a9ea-9d09c7e36d95} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 777, line 778) (in query: SELECT kostikConsistentHash(NULL, NULL, NULL);) 2025.06.13 15:57:18.489479 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:19.152154 [ 45013 ] {9c5f29b1-1f97-445d-a7c2-db532a68b518} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 782, line 783) (in query: SELECT lagInFrame(NULL, NULL, NULL);) 2025.06.13 15:57:19.164095 [ 45013 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.13 15:57:19.265393 [ 18510 ] {34cf459c-8971-4682-beb5-e294866e1ef2} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1121, line 374) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:19.277624 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:19.372749 [ 45013 ] {ac5db1aa-d2db-433b-82f3-f564e6cd26e4} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 784, line 785) (in query: SELECT lastValueRespectNulls(NULL, NULL, NULL);) 2025.06.13 15:57:19.382812 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:19.500557 [ 45013 ] {567216f4-2115-4559-a442-eee855ddac3a} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 786, line 787) (in query: SELECT last_value_respect_nulls(NULL, NULL, NULL);) 2025.06.13 15:57:19.508800 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:19.540246 [ 45013 ] {1e38e5b6-5abf-4052-b876-0b2113087bba} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 787, line 788) (in query: SELECT lcase(NULL, NULL, NULL);) 2025.06.13 15:57:19.547887 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:19.635802 [ 45013 ] {451d268f-907f-4560-96e9-958d520089d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 788, line 789) (in query: SELECT lcm(NULL, NULL, NULL);) 2025.06.13 15:57:19.644264 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:19.679096 [ 45013 ] {b6a691a2-a41b-4f88-ab4d-68a3dd5486b3} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 789, line 790) (in query: SELECT leadInFrame(NULL, NULL, NULL);) 2025.06.13 15:57:19.684722 [ 45013 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.13 15:57:19.772723 [ 45013 ] {2b7ead32-025f-4af7-b54f-24ca8a3c2fa1} executeQuery: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 791, line 792) (in query: SELECT left(NULL, NULL, NULL);) 2025.06.13 15:57:19.780099 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:19.958882 [ 18510 ] {3a29b5d5-3270-40ef-830e-0de1c5a948b6} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1127, line 376) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:19.968222 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:57:20.009244 [ 45013 ] {04f95a07-e1bb-4d55-a6de-2c878c9b26ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 794, line 795) (in query: SELECT leftUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:20.023004 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:20.023627 [ 3502 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0d1b968b-968f-4ab8-a5f8-7fab70495fd4::202506_1_196_51}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab57af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab1fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003122f56b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d8e4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:57:20.055875 [ 45013 ] {82d1c171-273c-4ed5-96d4-45a939a7b1e4} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 795, line 796) (in query: SELECT lemmatize(NULL, NULL, NULL);) 2025.06.13 15:57:20.061544 [ 45013 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:57:20.082266 [ 45013 ] {caa75e65-14d9-499d-805f-bef67276a43c} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 796, line 797) (in query: SELECT length(NULL, NULL, NULL);) 2025.06.13 15:57:20.086656 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:20.286633 [ 45013 ] {0e78e438-543f-426c-8f85-5080cd8e44cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 797, line 798) (in query: SELECT lengthUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:20.322319 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:20.371089 [ 45013 ] {ae9117f4-898d-47ae-82a9-fd3743ab229f} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 798, line 799) (in query: SELECT less(NULL, NULL, NULL);) 2025.06.13 15:57:20.379380 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:20.424741 [ 45013 ] {145bc2d0-a7f6-4b96-b5da-f9c1f21d909a} executeQuery: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 799, line 800) (in query: SELECT lessOrEquals(NULL, NULL, NULL);) 2025.06.13 15:57:20.433405 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:20.489860 [ 45013 ] {c6d9a34d-44c7-4d80-a0ae-7ba97305281f} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 800, line 801) (in query: SELECT levenshteinDistance(NULL, NULL, NULL);) 2025.06.13 15:57:20.497807 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:20.544234 [ 45013 ] {4028eaa0-b272-4b3e-93ac-595cd7a0d6b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 801, line 802) (in query: SELECT levenshteinDistanceUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:20.564949 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:20.607523 [ 45013 ] {9df83e09-a325-4886-b12b-09d75054005c} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 802, line 803) (in query: SELECT lgamma(NULL, NULL, NULL);) 2025.06.13 15:57:20.660262 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:20.691607 [ 45013 ] {7e6b585b-481d-4b38-ba1c-0a6928dc4965} executeQuery: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 803, line 804) (in query: SELECT like(NULL, NULL, NULL);) 2025.06.13 15:57:20.704947 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:20.743507 [ 45013 ] {3c4ea6b9-ee21-4f91-9c67-21c1d633ea16} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 804, line 805) (in query: SELECT ln(NULL, NULL, NULL);) 2025.06.13 15:57:20.749553 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:20.939269 [ 45013 ] {40ce3bc3-5f04-4f8b-8028-736d5d7be905} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 806, line 807) (in query: SELECT log(NULL, NULL, NULL);) 2025.06.13 15:57:20.955010 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:20.994886 [ 45013 ] {ead2cd2d-b71b-4f50-bb5f-13178153139d} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 807, line 808) (in query: SELECT log10(NULL, NULL, NULL);) 2025.06.13 15:57:21.009183 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:21.074536 [ 45013 ] {22833849-5207-4696-83ef-fa4c6500a633} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 808, line 809) (in query: SELECT log1p(NULL, NULL, NULL);) 2025.06.13 15:57:21.092318 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:21.141420 [ 45013 ] {d48ba029-ce41-4689-86a5-8dd3b27a30b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 809, line 810) (in query: SELECT log2(NULL, NULL, NULL);) 2025.06.13 15:57:21.154706 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:21.227189 [ 45013 ] {65d189eb-70f6-4aab-bf35-4e931d6bee7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 810, line 811) (in query: SELECT logTrace(NULL, NULL, NULL);) 2025.06.13 15:57:21.234040 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:21.289103 [ 45013 ] {05d0c1cf-cbc9-48c0-98e0-8f7c5036884d} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 811, line 812) (in query: SELECT lowCardinalityIndices(NULL, NULL, NULL);) 2025.06.13 15:57:21.296284 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:21.430571 [ 45013 ] {d7f76c11-993c-46de-ae4f-34a7da9fb75e} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 812, line 813) (in query: SELECT lowCardinalityKeys(NULL, NULL, NULL);) 2025.06.13 15:57:21.438347 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:21.489384 [ 45013 ] {6e2cb0e3-04f9-40b3-af76-f101d33f6cd5} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 813, line 814) (in query: SELECT lower(NULL, NULL, NULL);) 2025.06.13 15:57:21.499235 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:21.534249 [ 45013 ] {332f23d8-4d28-450e-9a41-9f014b54e647} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 814, line 815) (in query: SELECT lowerUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:21.542626 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:22.463246 [ 45013 ] {0e34f12b-ca80-4208-b319-9f2bd6d78b3a} executeQuery: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 822, line 824) (in query: SELECT map(NULL, NULL, NULL);) 2025.06.13 15:57:22.490287 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:22.759425 [ 45013 ] {b5820e1e-d049-4d19-9b99-663215bb8bfe} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 827, line 829) (in query: SELECT mapContains(NULL, NULL, NULL);) 2025.06.13 15:57:22.773879 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:23.071030 [ 45013 ] {c5b52fe6-6f49-4db5-95a2-de9e9ea1497f} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 832, line 834) (in query: SELECT mapFromArrays(NULL, NULL, NULL);) 2025.06.13 15:57:23.076996 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:23.397097 [ 45013 ] {3c78bdc4-1224-4680-997d-6cc94841716e} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 834, line 836) (in query: SELECT mapKeys(NULL, NULL, NULL);) 2025.06.13 15:57:23.405361 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:24.187360 [ 45013 ] {9f641ce5-3ae0-489e-a204-a6938979710b} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 841, line 843) (in query: SELECT mapUpdate(NULL, NULL, NULL);) 2025.06.13 15:57:24.197547 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:24.234273 [ 45013 ] {1fedb6c6-6972-423b-830d-25680ba25d4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 842, line 844) (in query: SELECT mapValues(NULL, NULL, NULL);) 2025.06.13 15:57:24.254964 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:24.299721 [ 45013 ] {df89d161-ad44-49aa-9597-2a7033bbae25} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 843, line 845) (in query: SELECT match(NULL, NULL, NULL);) 2025.06.13 15:57:24.309081 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:24.353190 [ 45013 ] {392e5532-01ab-4d5f-8362-1378ea353303} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 844, line 846) (in query: SELECT materialize(NULL, NULL, NULL);) 2025.06.13 15:57:24.362290 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:24.556025 [ 45013 ] {95dadf27-e8f4-4fab-b668-2b438ea23a6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 846, line 848) (in query: SELECT max2(NULL, NULL, NULL);) 2025.06.13 15:57:24.562512 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:27.373069 [ 45013 ] {bd0925c6-1f28-4df4-901b-9d3b6c8e3836} executeQuery: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 870, line 872) (in query: SELECT min2(NULL, NULL, NULL);) 2025.06.13 15:57:27.385621 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:27.580769 [ 45013 ] {4e3d0d4a-9f9e-4512-b94e-439f70f3ff47} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 872, line 874) (in query: SELECT minSampleSizeContinous(NULL, NULL, NULL);) 2025.06.13 15:57:27.597800 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:27.683530 [ 45013 ] {78073ce0-aae7-4069-a983-9dd6afc483db} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 873, line 875) (in query: SELECT minSampleSizeContinuous(NULL, NULL, NULL);) 2025.06.13 15:57:27.692012 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:27.799131 [ 45013 ] {1b8946a4-9c89-4c80-8e84-e517e2d9b7b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 874, line 876) (in query: SELECT minSampleSizeConversion(NULL, NULL, NULL);) 2025.06.13 15:57:27.813562 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:27.929112 [ 45013 ] {cabe3c0d-371e-43a9-8cf9-afaeb0d8c5da} executeQuery: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 875, line 877) (in query: SELECT minus(NULL, NULL, NULL);) 2025.06.13 15:57:27.937838 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:27.977202 [ 45013 ] {6ce8cebe-acab-4817-b483-c883d76ebad0} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 876, line 878) (in query: SELECT mismatches(NULL, NULL, NULL);) 2025.06.13 15:57:27.985270 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:28.080037 [ 45013 ] {b809b39f-14ab-46ec-b6b0-2d850eb209eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 877, line 879) (in query: SELECT mod(NULL, NULL, NULL);) 2025.06.13 15:57:28.087205 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:28.163824 [ 45013 ] {bb444db0-4bce-46c1-be7f-0608c7944cad} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 878, line 880) (in query: SELECT modulo(NULL, NULL, NULL);) 2025.06.13 15:57:28.170983 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:28.311599 [ 45013 ] {a0c62e75-6182-4750-9e20-b61c2cfecedd} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 879, line 881) (in query: SELECT moduloLegacy(NULL, NULL, NULL);) 2025.06.13 15:57:28.320364 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:28.353140 [ 45013 ] {d7be566a-7084-4063-8823-4e3a6fa77c85} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 880, line 882) (in query: SELECT moduloOrZero(NULL, NULL, NULL);) 2025.06.13 15:57:28.359045 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:28.399722 [ 45013 ] {8984e4f9-77c9-4cdc-beff-4567dde2bc10} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 881, line 883) (in query: SELECT monthName(NULL, NULL, NULL);) 2025.06.13 15:57:28.406487 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:28.624984 [ 45013 ] {7bf39757-4f1c-4d8a-89bc-d0675d8aabc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 882, line 884) (in query: SELECT mortonDecode(NULL, NULL, NULL);) 2025.06.13 15:57:28.632628 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:29.308884 [ 45013 ] {3886e95d-6d13-4a31-ac09-c68e82eb17aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 888, line 890) (in query: SELECT multiMatchAllIndices(NULL, NULL, NULL);) 2025.06.13 15:57:29.314516 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:29.419401 [ 45013 ] {ba1be0e8-d63b-4a91-aee5-486343c28afc} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 889, line 891) (in query: SELECT multiMatchAny(NULL, NULL, NULL);) 2025.06.13 15:57:29.480064 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:29.535977 [ 45013 ] {7c91427d-f4e3-481f-974d-39194d962559} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 890, line 892) (in query: SELECT multiMatchAnyIndex(NULL, NULL, NULL);) 2025.06.13 15:57:29.545442 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:29.685307 [ 45013 ] {512ceb12-ddbe-4aca-a72c-ff12bfac80c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 891, line 893) (in query: SELECT multiSearchAllPositions(NULL, NULL, NULL);) 2025.06.13 15:57:29.698732 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:29.793769 [ 45013 ] {c5a2c436-f60c-4c4c-ac8d-4de607786c15} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 892, line 894) (in query: SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL);) 2025.06.13 15:57:29.803970 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:29.868224 [ 45013 ] {6c1abbe4-5615-4f9b-a4bf-38ed3ec95799} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 893, line 895) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:29.874954 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:29.931890 [ 45013 ] {05726f4f-0903-4a91-a223-ddfd0edfcd48} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 894, line 896) (in query: SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:29.940276 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:29.995839 [ 45013 ] {15ffee9c-30b8-47d3-aa7c-90e4ac17fdc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 895, line 897) (in query: SELECT multiSearchAny(NULL, NULL, NULL);) 2025.06.13 15:57:30.010108 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:30.084604 [ 45013 ] {75b7e816-7cb4-48b7-b340-ff7abf9c505f} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 896, line 898) (in query: SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL);) 2025.06.13 15:57:30.092344 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:30.126712 [ 45013 ] {ec2feae9-508a-4112-bd1f-cba970a2e01d} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 897, line 899) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:30.133389 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:30.177737 [ 45013 ] {2eea6f34-c950-4c97-b11f-2aca67111ceb} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 898, line 900) (in query: SELECT multiSearchAnyUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:30.186586 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:30.228618 [ 45013 ] {58ecb465-6a44-44d4-b6d6-35d42abe548d} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 899, line 901) (in query: SELECT multiSearchFirstIndex(NULL, NULL, NULL);) 2025.06.13 15:57:30.234878 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:30.274923 [ 45013 ] {d0c8cc3a-1b73-4e48-b9b6-e95391fadf65} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 900, line 902) (in query: SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL);) 2025.06.13 15:57:30.288838 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:30.323002 [ 45013 ] {7141a9b5-eb9e-4fc7-ad2d-ef51c742ae16} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 901, line 903) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:30.388755 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:30.429119 [ 45013 ] {23d5f30a-527b-4c72-95f9-702f67946c1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 902, line 904) (in query: SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:30.435987 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:30.470580 [ 45013 ] {a8d43e37-73bd-40a5-9a9d-94ae4ed32da6} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 903, line 905) (in query: SELECT multiSearchFirstPosition(NULL, NULL, NULL);) 2025.06.13 15:57:30.478435 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:30.536467 [ 45013 ] {d26218ab-8ff0-4cd3-8f54-ae96fc5a2718} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 904, line 906) (in query: SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL);) 2025.06.13 15:57:30.547667 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:30.588690 [ 45013 ] {69032574-aa96-40e1-983e-9f47448ce590} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 905, line 907) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:30.594948 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:30.638340 [ 45013 ] {80a39b05-6f7a-461d-9051-76f92f2bf208} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 906, line 908) (in query: SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:30.653805 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:30.705265 [ 45013 ] {4495a388-446b-4459-9c50-4756db825574} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 907, line 909) (in query: SELECT multiply(NULL, NULL, NULL);) 2025.06.13 15:57:30.797736 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:31.549155 [ 45013 ] {a9bd7eda-cb06-4f20-bb2d-984a26cbab16} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 914, line 916) (in query: SELECT negate(NULL, NULL, NULL);) 2025.06.13 15:57:31.554934 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:31.587926 [ 45013 ] {8abcdec4-21c6-40a5-b5c3-4a25e42c60e0} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 915, line 917) (in query: SELECT neighbor(NULL, NULL, NULL);) 2025.06.13 15:57:31.599571 [ 45013 ] {} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:57:31.750158 [ 45013 ] {c1469111-5a4d-40b6-a332-71691fdf7cc1} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 917, line 919) (in query: SELECT netloc(NULL, NULL, NULL);) 2025.06.13 15:57:31.756023 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:31.790213 [ 45013 ] {5211ac26-5211-4b69-a44b-5ec141351bbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 918, line 920) (in query: SELECT ngramDistance(NULL, NULL, NULL);) 2025.06.13 15:57:31.799142 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:31.868807 [ 45013 ] {8bcb7015-6d6e-4edf-b332-25d033c98bd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 919, line 921) (in query: SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL);) 2025.06.13 15:57:31.880120 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:31.911016 [ 45013 ] {20a42bc3-af17-4478-8f15-c416524a42a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 920, line 922) (in query: SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:31.915971 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:32.022081 [ 45013 ] {1658db34-2d3f-4fc2-9cce-3aba01fb0fc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 921, line 923) (in query: SELECT ngramDistanceUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:32.029205 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:32.396599 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:57:32.934383 [ 45013 ] {32cc6220-f0d3-4615-981d-52d6008fe4c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 930, line 932) (in query: SELECT ngramSearch(NULL, NULL, NULL);) 2025.06.13 15:57:32.941570 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:32.973482 [ 45013 ] {76f5a1f5-0919-4640-810e-1f9e51d08cd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 931, line 933) (in query: SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL);) 2025.06.13 15:57:32.979379 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:33.058681 [ 45013 ] {6164acaf-c8b5-4b02-b922-8a976fd6bee6} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 932, line 934) (in query: SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:33.070325 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:33.129719 [ 45013 ] {afc1dcfa-42fb-4428-95ec-def4b4f634eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 933, line 935) (in query: SELECT ngramSearchUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:33.135819 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:33.565408 [ 45013 ] {1f5268c6-3030-4bbc-8731-4d85407da95c} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 938, line 940) (in query: SELECT ngrams(NULL, NULL, NULL);) 2025.06.13 15:57:33.572302 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:33.613995 [ 45013 ] {d1c64fef-ccd9-40e6-8c24-395db171232c} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 939, line 941) (in query: SELECT nonNegativeDerivative(NULL, NULL, NULL);) 2025.06.13 15:57:33.620594 [ 45013 ] {} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.06.13 15:57:33.661806 [ 45013 ] {9501dd1e-8950-4593-a737-e8663bb5b4ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 940, line 942) (in query: SELECT normL1(NULL, NULL, NULL);) 2025.06.13 15:57:33.677167 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:33.725359 [ 45013 ] {aea23255-82af-4472-8944-1c0563dc7644} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 941, line 943) (in query: SELECT normL2(NULL, NULL, NULL);) 2025.06.13 15:57:33.734142 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:33.880136 [ 45013 ] {466203ea-cae7-4f6b-87c2-f0eeeebe6b83} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 942, line 944) (in query: SELECT normL2Squared(NULL, NULL, NULL);) 2025.06.13 15:57:33.886206 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:33.918043 [ 45013 ] {93e1723c-8919-4c72-9b9c-e4a91c73df8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 943, line 945) (in query: SELECT normLinf(NULL, NULL, NULL);) 2025.06.13 15:57:33.925416 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:33.968865 [ 45013 ] {8bcdb7f6-8545-433b-87c0-bd8a726720cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 944, line 946) (in query: SELECT normLp(NULL, NULL, NULL);) 2025.06.13 15:57:33.975004 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.018611 [ 45013 ] {23a69c09-9b96-41c3-9346-b91c959b8dea} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 945, line 947) (in query: SELECT normalizeL1(NULL, NULL, NULL);) 2025.06.13 15:57:34.023596 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.061863 [ 45013 ] {b68a34ad-1d3b-4b82-b769-0943f8e6641e} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 946, line 948) (in query: SELECT normalizeL2(NULL, NULL, NULL);) 2025.06.13 15:57:34.071000 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.187176 [ 45013 ] {355ebc8d-aa18-4ca7-b50a-e2d6a8f106dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 947, line 949) (in query: SELECT normalizeLinf(NULL, NULL, NULL);) 2025.06.13 15:57:34.194714 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.231454 [ 45013 ] {3d387eb0-9c42-4896-9852-8d4d63ba4e01} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 948, line 950) (in query: SELECT normalizeLp(NULL, NULL, NULL);) 2025.06.13 15:57:34.240006 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.300710 [ 45013 ] {4bd74c0b-f223-4f12-8ddc-5a5fbd0e046e} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 949, line 951) (in query: SELECT normalizeQuery(NULL, NULL, NULL);) 2025.06.13 15:57:34.308571 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.335159 [ 45013 ] {b4e4c8ce-f05c-46ff-be4f-1ecbfcb8d19b} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 950, line 952) (in query: SELECT normalizeQueryKeepNames(NULL, NULL, NULL);) 2025.06.13 15:57:34.340013 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.374386 [ 45013 ] {0ef98f10-9c78-44f4-9410-a88c4c9d8032} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 951, line 953) (in query: SELECT normalizeUTF8NFC(NULL, NULL, NULL);) 2025.06.13 15:57:34.380919 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.412150 [ 45013 ] {aedd736c-05ea-4aab-b8e7-e6f3a2e2e7d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 952, line 954) (in query: SELECT normalizeUTF8NFD(NULL, NULL, NULL);) 2025.06.13 15:57:34.418628 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.488004 [ 45013 ] {1db511b8-6a5c-463b-a9d3-f715a4ef3b51} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 953, line 955) (in query: SELECT normalizeUTF8NFKC(NULL, NULL, NULL);) 2025.06.13 15:57:34.497131 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.535882 [ 45013 ] {26fad529-4a6f-4779-8105-71b16f015585} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 954, line 956) (in query: SELECT normalizeUTF8NFKD(NULL, NULL, NULL);) 2025.06.13 15:57:34.542109 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.579177 [ 45013 ] {c1294bea-d8e6-4478-a2fa-9982036e9192} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 955, line 957) (in query: SELECT normalizedQueryHash(NULL, NULL, NULL);) 2025.06.13 15:57:34.584048 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.617092 [ 45013 ] {6f4eabad-7410-43e1-93b6-c79a4b9b8bb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 956, line 958) (in query: SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL);) 2025.06.13 15:57:34.623833 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.656795 [ 45013 ] {57bc22d2-7508-4d53-a9f7-f12c63577c92} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 957, line 959) (in query: SELECT not(NULL, NULL, NULL);) 2025.06.13 15:57:34.663542 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.702917 [ 45013 ] {2c0846a4-b2bc-41de-a3ea-be1b76f519e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 958, line 960) (in query: SELECT notEmpty(NULL, NULL, NULL);) 2025.06.13 15:57:34.707834 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.737957 [ 45013 ] {8fa6bec0-fc3e-4854-bcd3-210324fc1c3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 959, line 961) (in query: SELECT notEquals(NULL, NULL, NULL);) 2025.06.13 15:57:34.757024 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.800018 [ 45013 ] {10d0664b-0848-403d-b54a-6ff561f84907} executeQuery: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 960, line 962) (in query: SELECT notILike(NULL, NULL, NULL);) 2025.06.13 15:57:34.806590 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.870648 [ 45013 ] {5b389dbb-8f9c-4b31-a68e-3d82b6a8fd55} executeQuery: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 961, line 963) (in query: SELECT notIn(NULL, NULL, NULL);) 2025.06.13 15:57:34.877989 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:34.928327 [ 45013 ] {a48a9494-21bb-402b-9eeb-7e96dba0f261} executeQuery: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 962, line 964) (in query: SELECT notInIgnoreSet(NULL, NULL, NULL);) 2025.06.13 15:57:34.941292 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:35.014158 [ 45013 ] {2127679f-5a4e-4477-a5ba-0925bcd2303c} executeQuery: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 963, line 965) (in query: SELECT notLike(NULL, NULL, NULL);) 2025.06.13 15:57:35.022676 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:35.127565 [ 45013 ] {2493ed7a-b50a-4b3c-912c-4c9c4be707ac} executeQuery: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 964, line 966) (in query: SELECT notNullIn(NULL, NULL, NULL);) 2025.06.13 15:57:35.134252 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:35.225102 [ 45013 ] {72b31a1e-36d3-4fac-a70a-5c8bb755c878} executeQuery: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 965, line 967) (in query: SELECT notNullInIgnoreSet(NULL, NULL, NULL);) 2025.06.13 15:57:35.232919 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:35.763916 [ 45013 ] {e71c07ab-4256-4802-8265-730d9389b7d4} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 969, line 971) (in query: SELECT now(NULL, NULL, NULL);) 2025.06.13 15:57:35.778166 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:36.073394 [ 45013 ] {7324372b-1732-4205-983e-c98a6a6062d3} executeQuery: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 972, line 974) (in query: SELECT nth_value(NULL, NULL, NULL);) 2025.06.13 15:57:36.094640 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:36.139358 [ 45013 ] {cb6c83fb-466b-4270-b86f-e97eb84450a6} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 973, line 975) (in query: SELECT ntile(NULL, NULL, NULL);) 2025.06.13 15:57:36.295271 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:36.353502 [ 45013 ] {8e3836f5-9950-431e-a3c2-8ddf778c4841} executeQuery: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 974, line 976) (in query: SELECT nullIf(NULL, NULL, NULL);) 2025.06.13 15:57:36.365827 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:36.420622 [ 45013 ] {7122429b-7526-4733-9de3-352e2d928535} executeQuery: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 975, line 977) (in query: SELECT nullIn(NULL, NULL, NULL);) 2025.06.13 15:57:36.428126 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:36.500019 [ 45013 ] {24108fbe-7a07-4c02-9024-f0f98ea54a5e} executeQuery: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 976, line 978) (in query: SELECT nullInIgnoreSet(NULL, NULL, NULL);) 2025.06.13 15:57:36.515161 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:36.598714 [ 45013 ] {31f06952-f6e1-4428-b9c1-8e9589e06593} executeQuery: Code: 36. DB::Exception: Lambda age_max -> (SELECT uid FROM users WHERE users.age < age_max ORDER BY users.age DESC LIMIT 1) expect 1 arguments. Actual 3. In scope age_max -> (SELECT uid FROM users WHERE users.age < age_max ORDER BY users.age DESC LIMIT 1). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 977, line 979) (in query: SELECT oldest_before(NULL, NULL, NULL);) 2025.06.13 15:57:36.608474 [ 45013 ] {} TCPHandler: Code: 36. DB::Exception: Lambda age_max -> (SELECT uid FROM users WHERE users.age < age_max ORDER BY users.age DESC LIMIT 1) expect 1 arguments. Actual 3. In scope age_max -> (SELECT uid FROM users WHERE users.age < age_max ORDER BY users.age DESC LIMIT 1). (BAD_ARGUMENTS) 2025.06.13 15:57:36.640098 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:57:39.032515 [ 45013 ] {a59e4c34-5398-4720-aa3f-34d7bc90904d} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1008, line 1010) (in query: SELECT parseReadableSize(NULL, NULL, NULL);) 2025.06.13 15:57:39.049624 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:39.175346 [ 45013 ] {6617306e-a53a-4143-8db5-a1ca1fa7c573} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1009, line 1011) (in query: SELECT parseReadableSizeOrNull(NULL, NULL, NULL);) 2025.06.13 15:57:39.179957 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:39.218177 [ 45013 ] {7428c543-7d56-406d-b453-9a32a9cb66c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1010, line 1012) (in query: SELECT parseReadableSizeOrZero(NULL, NULL, NULL);) 2025.06.13 15:57:39.224290 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:39.641194 [ 45013 ] {55ec59a0-7a2a-4f02-a7af-9999d11f5b9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1014, line 1016) (in query: SELECT path(NULL, NULL, NULL);) 2025.06.13 15:57:39.648440 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:39.782760 [ 45013 ] {b397d9d0-5d07-42bc-9d45-8ef29166d208} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1015, line 1017) (in query: SELECT pathFull(NULL, NULL, NULL);) 2025.06.13 15:57:39.787990 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:39.867196 [ 45013 ] {2bc6d154-156c-4b50-8fdd-ac6a5ad45119} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1016, line 1018) (in query: SELECT percentRank(NULL, NULL, NULL);) 2025.06.13 15:57:39.873919 [ 45013 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:57:39.934142 [ 45013 ] {55ea249f-c898-4319-bff5-8bb9c4e44fad} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1017, line 1019) (in query: SELECT percent_rank(NULL, NULL, NULL);) 2025.06.13 15:57:39.940716 [ 45013 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:57:40.041621 [ 45013 ] {0ce6d3db-a6f8-460b-9d55-f45bc371f321} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1018, line 1020) (in query: SELECT pi(NULL, NULL, NULL);) 2025.06.13 15:57:40.054852 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.104564 [ 45013 ] {13316287-8849-49ca-a5ba-63138199a706} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1019, line 1021) (in query: SELECT plus(NULL, NULL, NULL);) 2025.06.13 15:57:40.111465 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.145090 [ 45013 ] {d29f325d-ab59-41f0-8690-9cdc1ac307e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1020, line 1022) (in query: SELECT pmod(NULL, NULL, NULL);) 2025.06.13 15:57:40.153281 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.305152 [ 45013 ] {c82e41f8-241d-48f1-ae8b-1c0ee49d3a6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1023, line 1025) (in query: SELECT polygonAreaCartesian(NULL, NULL, NULL);) 2025.06.13 15:57:40.309671 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.339552 [ 45013 ] {c35540be-0675-4638-bb73-f548a08311fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1024, line 1026) (in query: SELECT polygonAreaSpherical(NULL, NULL, NULL);) 2025.06.13 15:57:40.354421 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.390985 [ 45013 ] {96d4c708-c752-41db-b756-b4d623baf432} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1025, line 1027) (in query: SELECT polygonConvexHullCartesian(NULL, NULL, NULL);) 2025.06.13 15:57:40.399675 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.433477 [ 45013 ] {3dc0496d-16af-4643-8463-eeb90a203a99} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1026, line 1028) (in query: SELECT polygonPerimeterCartesian(NULL, NULL, NULL);) 2025.06.13 15:57:40.440358 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.471781 [ 45013 ] {60a2d6b2-46a9-49a9-aebe-1290a57a2450} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1027, line 1029) (in query: SELECT polygonPerimeterSpherical(NULL, NULL, NULL);) 2025.06.13 15:57:40.533295 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.563044 [ 45013 ] {40212502-d170-4ddd-b3c0-1e1077413101} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1028, line 1030) (in query: SELECT polygonsDistanceCartesian(NULL, NULL, NULL);) 2025.06.13 15:57:40.570061 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.606251 [ 45013 ] {07c7e85a-b31b-49f4-824e-153f1a4c417d} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1029, line 1031) (in query: SELECT polygonsDistanceSpherical(NULL, NULL, NULL);) 2025.06.13 15:57:40.612873 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.649159 [ 45013 ] {8960bcd5-7989-4128-9e3d-34e93485f15b} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1030, line 1032) (in query: SELECT polygonsEqualsCartesian(NULL, NULL, NULL);) 2025.06.13 15:57:40.655476 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.686998 [ 45013 ] {1b764332-bac3-4852-9954-5e71ab43853d} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1031, line 1033) (in query: SELECT polygonsIntersectionCartesian(NULL, NULL, NULL);) 2025.06.13 15:57:40.693434 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.726077 [ 45013 ] {a72aaf62-051b-4907-ad90-ae1e22c08ea0} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1032, line 1034) (in query: SELECT polygonsIntersectionSpherical(NULL, NULL, NULL);) 2025.06.13 15:57:40.732573 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.765422 [ 45013 ] {4ebdec81-6bc7-4865-ac90-3aff2120688b} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1033, line 1035) (in query: SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL);) 2025.06.13 15:57:40.772444 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.816066 [ 45013 ] {1977cee8-f590-4084-a218-bed411afa5ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1034, line 1036) (in query: SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL);) 2025.06.13 15:57:40.822442 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.860811 [ 45013 ] {d2133ade-7d27-49ee-ac34-416c57284913} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1035, line 1037) (in query: SELECT polygonsUnionCartesian(NULL, NULL, NULL);) 2025.06.13 15:57:40.867443 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:40.936762 [ 45013 ] {30d54941-bbf8-43d8-aa30-220c5dc80acc} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1036, line 1038) (in query: SELECT polygonsUnionSpherical(NULL, NULL, NULL);) 2025.06.13 15:57:40.944821 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:41.088536 [ 45013 ] {d3a076e5-ca86-4094-9b08-c84197b73656} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1037, line 1039) (in query: SELECT polygonsWithinCartesian(NULL, NULL, NULL);) 2025.06.13 15:57:41.095037 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:41.127884 [ 45013 ] {cb654017-d840-4ebc-9350-be805f988cd3} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1038, line 1040) (in query: SELECT polygonsWithinSpherical(NULL, NULL, NULL);) 2025.06.13 15:57:41.134264 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:41.512260 [ 45013 ] {25fdcefb-060d-4f8b-8a07-7b92b3f7443f} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1045, line 1047) (in query: SELECT positiveModulo(NULL, NULL, NULL);) 2025.06.13 15:57:41.518433 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:41.550230 [ 45013 ] {67457117-3bcf-4953-ae39-84bc336156fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1046, line 1048) (in query: SELECT positive_modulo(NULL, NULL, NULL);) 2025.06.13 15:57:41.556700 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:41.580994 [ 45013 ] {8f996734-248d-4065-b0b9-dcbfcc9bc1c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1047, line 1049) (in query: SELECT pow(NULL, NULL, NULL);) 2025.06.13 15:57:41.586918 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:41.628806 [ 45013 ] {aff912d8-d737-4c27-87d2-3f55cece1e19} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1048, line 1050) (in query: SELECT power(NULL, NULL, NULL);) 2025.06.13 15:57:41.635499 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:41.832283 [ 45013 ] {a7ca7156-83d1-4a59-ae40-bb60d868e310} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1050, line 1052) (in query: SELECT proportionsZTest(NULL, NULL, NULL);) 2025.06.13 15:57:41.839999 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:41.869421 [ 45013 ] {138d4748-58b1-4797-8a3b-0ef0c32b315b} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1051, line 1053) (in query: SELECT protocol(NULL, NULL, NULL);) 2025.06.13 15:57:41.875214 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:41.907267 [ 45013 ] {0f470f7e-592c-4d54-89ae-65929c9245e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1052, line 1054) (in query: SELECT punycodeDecode(NULL, NULL, NULL);) 2025.06.13 15:57:41.914377 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:41.954958 [ 45013 ] {167cf22f-742b-4272-9ce8-aeb938d76ad3} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1053, line 1055) (in query: SELECT punycodeEncode(NULL, NULL, NULL);) 2025.06.13 15:57:41.965360 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:44.302856 [ 45013 ] {54f1c980-96be-42f0-8ac8-5c9d2e95bfd6} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1072, line 1074) (in query: SELECT quantiles(NULL, NULL, NULL);) 2025.06.13 15:57:44.311483 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:44.346362 [ 45013 ] {ace8b430-4062-48a6-acc6-acc4b88ca43a} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1073, line 1075) (in query: SELECT quantilesBFloat16(NULL, NULL, NULL);) 2025.06.13 15:57:44.352503 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:44.595469 [ 45013 ] {26471823-476a-4673-ad2c-d11e49e439aa} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1075, line 1077) (in query: SELECT quantilesDD(NULL, NULL, NULL);) 2025.06.13 15:57:44.603658 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:44.637794 [ 45013 ] {2d274b32-6c58-4206-a4af-be616ece3b57} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1076, line 1078) (in query: SELECT quantilesDeterministic(NULL, NULL, NULL);) 2025.06.13 15:57:44.644643 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:44.671838 [ 45013 ] {5005a126-ae26-4c14-8887-b0e52c741e53} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1077, line 1079) (in query: SELECT quantilesExact(NULL, NULL, NULL);) 2025.06.13 15:57:44.678152 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:44.706855 [ 45013 ] {1981901e-a2a2-4663-a8cf-ab3100fc455c} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1078, line 1080) (in query: SELECT quantilesExactExclusive(NULL, NULL, NULL);) 2025.06.13 15:57:44.712646 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:44.743383 [ 45013 ] {d1949f89-55fa-4eee-abe1-23e6dfbcb31c} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1079, line 1081) (in query: SELECT quantilesExactHigh(NULL, NULL, NULL);) 2025.06.13 15:57:44.750787 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:44.788247 [ 45013 ] {673f4413-0642-46a1-8c6d-417fea255ecf} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1080, line 1082) (in query: SELECT quantilesExactInclusive(NULL, NULL, NULL);) 2025.06.13 15:57:44.795504 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:44.932478 [ 45013 ] {85ec18b0-7ad9-4335-97ce-f6a4964dc87d} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1081, line 1083) (in query: SELECT quantilesExactLow(NULL, NULL, NULL);) 2025.06.13 15:57:44.939563 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:45.070569 [ 45013 ] {c5b19fd8-0082-4767-a87e-adc1c76f672d} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1082, line 1084) (in query: SELECT quantilesExactWeighted(NULL, NULL, NULL);) 2025.06.13 15:57:45.076872 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:45.110613 [ 45013 ] {cfdcd494-8685-47e5-a4ba-e085fe99311f} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1083, line 1085) (in query: SELECT quantilesExactWeightedInterpolated(NULL, NULL, NULL);) 2025.06.13 15:57:45.117355 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:45.179007 [ 45013 ] {83e1b61b-ce64-4143-b610-d03c32b58ae5} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1084, line 1086) (in query: SELECT quantilesGK(NULL, NULL, NULL);) 2025.06.13 15:57:45.185758 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:45.210034 [ 45013 ] {36acc376-0119-4785-9184-7df3f601bf82} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1085, line 1087) (in query: SELECT quantilesInterpolatedWeighted(NULL, NULL, NULL);) 2025.06.13 15:57:45.213644 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:45.241400 [ 45013 ] {5e46f44b-fe12-4833-a2a0-5824a76ba597} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1086, line 1088) (in query: SELECT quantilesTDigest(NULL, NULL, NULL);) 2025.06.13 15:57:45.250187 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:45.286982 [ 45013 ] {7ade4525-873e-4281-b89b-b1344f34159e} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1087, line 1089) (in query: SELECT quantilesTDigestWeighted(NULL, NULL, NULL);) 2025.06.13 15:57:45.292268 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:45.320883 [ 45013 ] {f28330b2-817e-4a08-a984-4688e28435ac} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1088, line 1090) (in query: SELECT quantilesTiming(NULL, NULL, NULL);) 2025.06.13 15:57:45.327684 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:45.366944 [ 45013 ] {71f9fbf8-fea5-422c-912c-6ef298271e10} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1089, line 1091) (in query: SELECT quantilesTimingWeighted(NULL, NULL, NULL);) 2025.06.13 15:57:45.372767 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:45.467438 [ 45013 ] {e8dbe5b3-a96a-46f2-86ca-4fcfee3a7250} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1090, line 1092) (in query: SELECT queryID(NULL, NULL, NULL);) 2025.06.13 15:57:45.530207 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:45.626748 [ 45013 ] {fc68d228-a693-4c0f-8d02-e9902b42364b} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1091, line 1093) (in query: SELECT queryString(NULL, NULL, NULL);) 2025.06.13 15:57:45.633845 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:45.670335 [ 45013 ] {15f01597-c6ab-474e-b589-0cd06b5309f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1092, line 1094) (in query: SELECT queryStringAndFragment(NULL, NULL, NULL);) 2025.06.13 15:57:45.675453 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:45.766110 [ 45013 ] {e2252895-91b9-4933-90e4-950e250e05f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1093, line 1095) (in query: SELECT query_id(NULL, NULL, NULL);) 2025.06.13 15:57:45.772517 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:45.884254 [ 45013 ] {7dc2fcf5-f05f-43e0-9ca5-da0ee07d8d0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1094, line 1096) (in query: SELECT radians(NULL, NULL, NULL);) 2025.06.13 15:57:45.891952 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:45.932742 [ 45013 ] {748a5f1e-b167-4760-bc47-1202bddf63d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1095, line 1097) (in query: SELECT rand(NULL, NULL, NULL);) 2025.06.13 15:57:45.942948 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:46.032730 [ 45013 ] {5df7bcc1-92aa-49a0-8bb4-958a70703752} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1096, line 1098) (in query: SELECT rand32(NULL, NULL, NULL);) 2025.06.13 15:57:46.036843 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:46.063382 [ 45013 ] {25508c6e-9d50-4fab-8ada-4081ae1180e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1097, line 1099) (in query: SELECT rand64(NULL, NULL, NULL);) 2025.06.13 15:57:46.068625 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:46.265130 [ 45013 ] {d779dd15-bc99-4992-930f-4e28b62adcc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1100, line 1102) (in query: SELECT randCanonical(NULL, NULL, NULL);) 2025.06.13 15:57:46.273142 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:46.375043 [ 45013 ] {cb760af5-c089-40ec-94ae-a3820e970981} executeQuery: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1102, line 1104) (in query: SELECT randConstant(NULL, NULL, NULL);) 2025.06.13 15:57:46.381123 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:47.069135 [ 45013 ] {5792a4b3-1ccb-4433-a74f-fd72a45e5f04} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1111, line 1113) (in query: SELECT randomFixedString(NULL, NULL, NULL);) 2025.06.13 15:57:47.081914 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:47.355892 [ 45013 ] {13daf8d4-8e8c-408a-9467-91459fa96b6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1114, line 1116) (in query: SELECT randomStringUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:47.363127 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:47.559842 [ 45013 ] {c63ab1fb-55df-49fc-b686-592ea552a196} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1116, line 1118) (in query: SELECT rank(NULL, NULL, NULL);) 2025.06.13 15:57:47.565339 [ 45013 ] {} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:57:47.691209 [ 45013 ] {5672e4ed-e6c5-473a-8714-ca4300dade54} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1118, line 1120) (in query: SELECT readWKTLineString(NULL, NULL, NULL);) 2025.06.13 15:57:47.698525 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:47.734929 [ 45013 ] {e64f648b-7b45-4938-8b50-80a6992a1c3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1119, line 1121) (in query: SELECT readWKTMultiLineString(NULL, NULL, NULL);) 2025.06.13 15:57:47.741761 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:47.780660 [ 45013 ] {fe50a417-03a9-4865-8a7e-eaf828e74497} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1120, line 1122) (in query: SELECT readWKTMultiPolygon(NULL, NULL, NULL);) 2025.06.13 15:57:47.790148 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:47.829101 [ 45013 ] {fb9f2213-9d36-4e92-9ab6-c20ba7cc5be9} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1121, line 1123) (in query: SELECT readWKTPoint(NULL, NULL, NULL);) 2025.06.13 15:57:47.837479 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:47.872778 [ 45013 ] {c8909027-d682-492c-9cde-495d0eb85d47} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1122, line 1124) (in query: SELECT readWKTPolygon(NULL, NULL, NULL);) 2025.06.13 15:57:47.881086 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:47.912010 [ 45013 ] {fd82a256-dfc5-479d-b697-1c968fde1af7} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1123, line 1125) (in query: SELECT readWKTRing(NULL, NULL, NULL);) 2025.06.13 15:57:47.917752 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:48.004675 [ 45013 ] {7421d757-5d5a-43a7-a1dd-99047bc332e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1125, line 1127) (in query: SELECT regexpQuoteMeta(NULL, NULL, NULL);) 2025.06.13 15:57:48.010779 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.172947 [ 45013 ] {b50abb6a-726b-423b-ba4c-196965760544} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1136, line 1138) (in query: SELECT reinterpret(NULL, NULL, NULL);) 2025.06.13 15:57:49.179695 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.214129 [ 45013 ] {14558147-a534-4b3b-827e-822d7ce3361d} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1137, line 1139) (in query: SELECT reinterpretAsDate(NULL, NULL, NULL);) 2025.06.13 15:57:49.221575 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.256405 [ 45013 ] {e1d29e6e-b82d-4ea6-973f-39cb287673df} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1138, line 1140) (in query: SELECT reinterpretAsDateTime(NULL, NULL, NULL);) 2025.06.13 15:57:49.262901 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.302599 [ 45013 ] {22ab6433-5fe1-4d25-9e7c-e38dd2f5dc59} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1139, line 1141) (in query: SELECT reinterpretAsFixedString(NULL, NULL, NULL);) 2025.06.13 15:57:49.308921 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.349822 [ 45013 ] {aaf192a4-60e1-43ee-9aed-a7e6647e9069} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1140, line 1142) (in query: SELECT reinterpretAsFloat32(NULL, NULL, NULL);) 2025.06.13 15:57:49.364946 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.393204 [ 45013 ] {e21a831b-9e4e-4d75-bd33-2e78da4cdc70} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1141, line 1143) (in query: SELECT reinterpretAsFloat64(NULL, NULL, NULL);) 2025.06.13 15:57:49.400318 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.433290 [ 45013 ] {a1ca4d16-9977-4527-b5f1-19791f2e7eaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1142, line 1144) (in query: SELECT reinterpretAsInt128(NULL, NULL, NULL);) 2025.06.13 15:57:49.438839 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.479092 [ 45013 ] {373e22a6-406a-4b35-9400-037b869b6c3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1143, line 1145) (in query: SELECT reinterpretAsInt16(NULL, NULL, NULL);) 2025.06.13 15:57:49.485116 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.525261 [ 45013 ] {dbbdac27-1808-40a9-bbc3-17f9e0e0d632} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1144, line 1146) (in query: SELECT reinterpretAsInt256(NULL, NULL, NULL);) 2025.06.13 15:57:49.530349 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.562704 [ 45013 ] {16f1d68b-a069-4720-9979-b30d3a332e28} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1145, line 1147) (in query: SELECT reinterpretAsInt32(NULL, NULL, NULL);) 2025.06.13 15:57:49.567012 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.600221 [ 45013 ] {488ce445-2c32-42dd-b726-44d516e86a67} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1146, line 1148) (in query: SELECT reinterpretAsInt64(NULL, NULL, NULL);) 2025.06.13 15:57:49.606465 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.636866 [ 45013 ] {3c80ec82-bb32-4850-a64a-a919b96489a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1147, line 1149) (in query: SELECT reinterpretAsInt8(NULL, NULL, NULL);) 2025.06.13 15:57:49.641981 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.679125 [ 45013 ] {a86877a0-daa2-4062-9702-17f9282e18d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1148, line 1150) (in query: SELECT reinterpretAsString(NULL, NULL, NULL);) 2025.06.13 15:57:49.685513 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.783568 [ 45013 ] {420b9db6-4401-4907-ae59-322156b73a57} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1149, line 1151) (in query: SELECT reinterpretAsUInt128(NULL, NULL, NULL);) 2025.06.13 15:57:49.789483 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.825693 [ 45013 ] {722e2f52-2171-4cd8-9dcc-ea4dba204724} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1150, line 1152) (in query: SELECT reinterpretAsUInt16(NULL, NULL, NULL);) 2025.06.13 15:57:49.833221 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.867089 [ 45013 ] {a9dcdde8-7096-4e5c-8f94-061736204b69} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1151, line 1153) (in query: SELECT reinterpretAsUInt256(NULL, NULL, NULL);) 2025.06.13 15:57:49.873698 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.908885 [ 45013 ] {b23a29db-e044-4949-b54e-0d4b3adc0002} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1152, line 1154) (in query: SELECT reinterpretAsUInt32(NULL, NULL, NULL);) 2025.06.13 15:57:49.916216 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:49.960023 [ 45013 ] {fd84b06a-8922-46c2-a509-6406920e1cd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1153, line 1155) (in query: SELECT reinterpretAsUInt64(NULL, NULL, NULL);) 2025.06.13 15:57:49.967585 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:50.004244 [ 45013 ] {6afea2aa-7436-4f2f-ae36-6e571da46b60} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1154, line 1156) (in query: SELECT reinterpretAsUInt8(NULL, NULL, NULL);) 2025.06.13 15:57:50.010508 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:50.063246 [ 45013 ] {1bb0a7fc-5ad3-4a4e-bb5b-6ea32211116f} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1155, line 1157) (in query: SELECT reinterpretAsUUID(NULL, NULL, NULL);) 2025.06.13 15:57:50.069426 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:50.105060 [ 45013 ] {c35e7c1e-dcd1-4528-b9fd-7ee42f9609cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1156, line 1158) (in query: SELECT repeat(NULL, NULL, NULL);) 2025.06.13 15:57:50.112699 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:50.546652 [ 45013 ] {f15dee32-2cda-4da2-99d9-7e8462946422} executeQuery: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1162, line 1164) (in query: SELECT replicate(NULL, NULL, NULL);) 2025.06.13 15:57:50.553592 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:57:50.688766 [ 45013 ] {d4e7dd4d-2ebc-41b5-9b2f-21dd0d9b01e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1164, line 1166) (in query: SELECT reverse(NULL, NULL, NULL);) 2025.06.13 15:57:50.695560 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:50.774587 [ 45013 ] {764a1d9b-2ce5-47e1-8062-db7c62cbf6d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1165, line 1167) (in query: SELECT reverseUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:50.780575 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:50.825694 [ 45013 ] {fe96dbae-b173-4e32-a59f-55af1e801649} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1166, line 1168) (in query: SELECT revision(NULL, NULL, NULL);) 2025.06.13 15:57:50.831481 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:50.861445 [ 45013 ] {9560f523-5c7d-4ffe-a411-6187f4c4f11a} executeQuery: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1167, line 1169) (in query: SELECT right(NULL, NULL, NULL);) 2025.06.13 15:57:50.958061 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:51.196242 [ 45013 ] {813b10bc-dcbe-4d70-8fd4-ca524042acb7} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1170, line 1172) (in query: SELECT rightUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:51.205583 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:51.295735 [ 45013 ] {0aab4264-2846-49f8-bd86-b431a0833e76} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1172, line 1174) (in query: SELECT roundAge(NULL, NULL, NULL);) 2025.06.13 15:57:51.302717 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:51.400341 [ 45013 ] {d38dc133-6064-41ee-8b86-7c0149d61988} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1174, line 1176) (in query: SELECT roundDown(NULL, NULL, NULL);) 2025.06.13 15:57:51.408139 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:51.443031 [ 45013 ] {e6b5dfcf-cb5c-402e-bb32-24f655fe6f5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1175, line 1177) (in query: SELECT roundDuration(NULL, NULL, NULL);) 2025.06.13 15:57:51.449678 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:51.487859 [ 45013 ] {7506971b-0bc6-4e80-bc8a-66357c121dae} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1176, line 1178) (in query: SELECT roundToExp2(NULL, NULL, NULL);) 2025.06.13 15:57:51.495066 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:51.537770 [ 45013 ] {f9893f7f-2e6e-46ea-a69e-3ddf2574a9e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1177, line 1179) (in query: SELECT rowNumberInAllBlocks(NULL, NULL, NULL);) 2025.06.13 15:57:51.545197 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:51.654465 [ 45013 ] {7ecf9d1d-8348-4e7a-8bf4-3a1aa023c49f} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1178, line 1180) (in query: SELECT rowNumberInBlock(NULL, NULL, NULL);) 2025.06.13 15:57:51.674586 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:51.809315 [ 45013 ] {e93ee767-1c3e-4d34-abcc-23552c8e8d74} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1179, line 1181) (in query: SELECT row_number(NULL, NULL, NULL);) 2025.06.13 15:57:51.815226 [ 45013 ] {} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.06.13 15:57:51.922758 [ 45013 ] {5ee5ae4b-2811-4231-a9fb-47e49a7f1b1b} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1181, line 1184) (in query: SELECT runningAccumulate(NULL, NULL, NULL);) 2025.06.13 15:57:51.928741 [ 45013 ] {} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:57:51.952435 [ 45013 ] {3c7026ef-df58-45c1-8cda-92c646faa970} executeQuery: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1182, line 1185) (in query: SELECT runningConcurrency(NULL, NULL, NULL);) 2025.06.13 15:57:51.958258 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:51.985857 [ 45013 ] {569d3439-abfb-41fb-a5a7-4dfbe45ad5d2} 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.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1183, line 1186) (in query: SELECT runningDifference(NULL, NULL, NULL);) 2025.06.13 15:57:51.990812 [ 45013 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:57:52.110178 [ 45013 ] {0c0a9656-3f25-4a76-94d3-e626b784fc39} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1184, line 1187) (in query: SELECT runningDifferenceStartingWithFirstValue(NULL, NULL, NULL);) 2025.06.13 15:57:52.116241 [ 45013 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.06.13 15:57:52.291558 [ 45013 ] {e0185f9b-a277-4e3f-9bce-0a6d9c1f2b35} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1186, line 1189) (in query: SELECT s2CapUnion(NULL, NULL, NULL);) 2025.06.13 15:57:52.381481 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:52.449012 [ 45013 ] {e2226263-9387-433b-925c-fb06814b19be} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1187, line 1190) (in query: SELECT s2CellsIntersect(NULL, NULL, NULL);) 2025.06.13 15:57:52.457227 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:52.485807 [ 45013 ] {5b68ddda-e478-41b5-a6fe-8ceaa84c95b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1188, line 1191) (in query: SELECT s2GetNeighbors(NULL, NULL, NULL);) 2025.06.13 15:57:52.491876 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:52.828683 [ 45013 ] {e4d507bf-10d2-48dd-b897-8c0554e6de1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1191, line 1194) (in query: SELECT s2RectIntersection(NULL, NULL, NULL);) 2025.06.13 15:57:52.835326 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:52.867128 [ 45013 ] {13d30ca6-0561-4a4f-bb97-c0fc796248ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1192, line 1195) (in query: SELECT s2RectUnion(NULL, NULL, NULL);) 2025.06.13 15:57:52.872565 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:52.916878 [ 45013 ] {6dda93dd-1c4d-4075-8c1a-6de7f14fa1a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1193, line 1196) (in query: SELECT s2ToGeo(NULL, NULL, NULL);) 2025.06.13 15:57:52.923288 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:52.961231 [ 45013 ] {c3bc130b-2538-4fdf-a030-b9c84f0b86d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1194, line 1197) (in query: SELECT scalarProduct(NULL, NULL, NULL);) 2025.06.13 15:57:52.968875 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:53.473424 [ 45013 ] {e0f9bd69-309d-421a-83dc-2e017138ae77} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1198, line 1201) (in query: SELECT sequenceNextNode(NULL, NULL, NULL);) 2025.06.13 15:57:53.480944 [ 45013 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.06.13 15:57:53.603824 [ 45013 ] {bf2153dd-007a-4e98-9834-34bbc04ddd86} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1199, line 1202) (in query: SELECT seriesDecomposeSTL(NULL, NULL, NULL);) 2025.06.13 15:57:53.610589 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:53.868423 [ 45013 ] {fc7edea5-611f-4289-bc10-dd16c3218607} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1201, line 1204) (in query: SELECT seriesPeriodDetectFFT(NULL, NULL, NULL);) 2025.06.13 15:57:53.876440 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:53.908321 [ 45013 ] {07814b15-61a1-4a8d-a1e2-cde72598fa79} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1202, line 1205) (in query: SELECT serverTimeZone(NULL, NULL, NULL);) 2025.06.13 15:57:53.921191 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:53.954697 [ 45013 ] {1485d831-0a39-4712-b3a3-26ac51f52b38} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1203, line 1206) (in query: SELECT serverTimezone(NULL, NULL, NULL);) 2025.06.13 15:57:53.961482 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:54.007090 [ 45013 ] {461d52ca-96f5-4d52-a242-8ab73c68dc2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1204, line 1207) (in query: SELECT serverUUID(NULL, NULL, NULL);) 2025.06.13 15:57:54.018147 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:54.153479 [ 45013 ] {c995f57c-df91-4094-97b0-3dd78628a9a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1205, line 1208) (in query: SELECT shardCount(NULL, NULL, NULL);) 2025.06.13 15:57:54.170631 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:54.248468 [ 45013 ] {a72df513-4eee-4f39-b4ae-a92af0654e28} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1206, line 1209) (in query: SELECT shardNum(NULL, NULL, NULL);) 2025.06.13 15:57:54.255161 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:54.291349 [ 45013 ] {166824af-9bad-46c8-8d9a-bee655c2a8c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1207, line 1210) (in query: SELECT showCertificate(NULL, NULL, NULL);) 2025.06.13 15:57:54.298685 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:54.334973 [ 45013 ] {1c4607ac-a537-4242-8008-324a78759135} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1208, line 1211) (in query: SELECT sigmoid(NULL, NULL, NULL);) 2025.06.13 15:57:54.343381 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:54.445184 [ 45013 ] {e25b0a2b-ebb5-4b6b-b778-28321f663e22} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1209, line 1212) (in query: SELECT sign(NULL, NULL, NULL);) 2025.06.13 15:57:54.451200 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:54.491246 [ 45013 ] {4d0ed38c-28bc-42a5-87e1-5f51fd2850fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1210, line 1213) (in query: SELECT simpleJSONExtractBool(NULL, NULL, NULL);) 2025.06.13 15:57:54.498359 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:54.532656 [ 45013 ] {c696f4ee-f123-4ec8-ab55-4b2a029bbeab} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1211, line 1214) (in query: SELECT simpleJSONExtractFloat(NULL, NULL, NULL);) 2025.06.13 15:57:54.547552 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:54.665966 [ 45013 ] {b235c394-7dad-4669-bc15-97f6b5a55773} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1212, line 1215) (in query: SELECT simpleJSONExtractInt(NULL, NULL, NULL);) 2025.06.13 15:57:54.678451 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:54.743571 [ 45013 ] {e4849b04-133a-4504-a03c-d5a461724d88} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1213, line 1216) (in query: SELECT simpleJSONExtractRaw(NULL, NULL, NULL);) 2025.06.13 15:57:54.752577 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:54.789144 [ 45013 ] {8788f7bc-c0e4-438d-abf2-61c1a749817f} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1214, line 1217) (in query: SELECT simpleJSONExtractString(NULL, NULL, NULL);) 2025.06.13 15:57:54.803375 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:54.846709 [ 45013 ] {9223be17-50d3-4763-9962-a085b63bca95} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1215, line 1218) (in query: SELECT simpleJSONExtractUInt(NULL, NULL, NULL);) 2025.06.13 15:57:54.854619 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:54.978558 [ 45013 ] {6cafd1fb-bb57-4453-ae62-f53ac4e37074} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1216, line 1219) (in query: SELECT simpleJSONHas(NULL, NULL, NULL);) 2025.06.13 15:57:54.987180 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:55.149527 [ 45013 ] {476c18df-769d-4a8e-8ffd-79ad5141c784} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1218, line 1221) (in query: SELECT sin(NULL, NULL, NULL);) 2025.06.13 15:57:55.154709 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:55.298709 [ 45013 ] {00dacbaf-ea0b-42d9-83f3-72113672153d} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1220, line 1223) (in query: SELECT sinh(NULL, NULL, NULL);) 2025.06.13 15:57:55.304153 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:56.160484 [ 45013 ] {f9b9a41e-9e55-43a4-9d74-a80914d27178} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1229, line 1232) (in query: SELECT sleep(NULL, NULL, NULL);) 2025.06.13 15:57:56.168343 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:56.205310 [ 45013 ] {f9eff5a5-06ba-437d-8644-77bbfa93456f} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1230, line 1233) (in query: SELECT sleepEachRow(NULL, NULL, NULL);) 2025.06.13 15:57:56.219022 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:56.750043 [ 45013 ] {d1fa7623-bd26-410c-9397-bb52877e91ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1235, line 1238) (in query: SELECT soundex(NULL, NULL, NULL);) 2025.06.13 15:57:56.775078 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:56.846536 [ 45013 ] {4b555706-b9fd-4f0c-b461-bee8999304b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1236, line 1239) (in query: SELECT space(NULL, NULL, NULL);) 2025.06.13 15:57:56.853472 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:58.116037 [ 45013 ] {848638d9-e296-44a4-8393-7b74e30c6b8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1246, line 1249) (in query: SELECT sqidDecode(NULL, NULL, NULL);) 2025.06.13 15:57:58.123207 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:58.324488 [ 45013 ] {1f6404e3-d5f9-4664-95b9-8b6f3e7d012f} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1248, line 1251) (in query: SELECT sqrt(NULL, NULL, NULL);) 2025.06.13 15:57:58.331195 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:58.373641 [ 45013 ] {e6374c18-8611-41ab-8b5d-c5f949c36072} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1249, line 1252) (in query: SELECT startsWith(NULL, NULL, NULL);) 2025.06.13 15:57:58.383261 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:58.435006 [ 45013 ] {983182b9-3471-4511-b704-fb5f2d8100fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1250, line 1253) (in query: SELECT startsWithUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:58.443397 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:59.329100 [ 45013 ] {358dd71b-5f96-45be-8b80-c0944d7c93ff} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1255, line 1258) (in query: SELECT stem(NULL, NULL, NULL);) 2025.06.13 15:57:59.342585 [ 45013 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:57:59.716602 [ 45013 ] {d011862a-7d23-44dc-a665-3e4105534ad9} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1260, line 1263) (in query: SELECT stringJaccardIndex(NULL, NULL, NULL);) 2025.06.13 15:57:59.721208 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:59.807985 [ 45013 ] {1b3bab3b-a9f1-4855-83a7-e13057c9c8a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1261, line 1264) (in query: SELECT stringJaccardIndexUTF8(NULL, NULL, NULL);) 2025.06.13 15:57:59.812144 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:59.842217 [ 45013 ] {f143104c-fbee-4d7b-84f3-099273291c5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1262, line 1265) (in query: SELECT stringToH3(NULL, NULL, NULL);) 2025.06.13 15:57:59.848493 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:59.881638 [ 45013 ] {6e5fff6d-9b90-4854-9937-b11ce3b2d5ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1263, line 1266) (in query: SELECT structureToCapnProtoSchema(NULL, NULL, NULL);) 2025.06.13 15:57:59.887147 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:57:59.921825 [ 45013 ] {ae25c28c-bf25-4a0f-bf82-599b124820cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1264, line 1267) (in query: SELECT structureToProtobufSchema(NULL, NULL, NULL);) 2025.06.13 15:57:59.928076 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:00.363713 [ 45013 ] {1b2901ae-f2fd-4bab-9d92-19a528c9aaf0} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1267, line 1270) (in query: SELECT subDate(NULL, NULL, NULL);) 2025.06.13 15:58:00.369707 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:01.049975 [ 45013 ] {3de985e7-9e44-4aee-80be-97affe337e99} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1275, line 1278) (in query: SELECT subtractInterval(NULL, NULL, NULL);) 2025.06.13 15:58:01.057032 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:01.695766 [ 45013 ] {7478bb4f-fa43-4584-91fe-d37061307e59} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1283, line 1286) (in query: SELECT subtractTupleOfIntervals(NULL, NULL, NULL);) 2025.06.13 15:58:01.702231 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:03.025078 [ 45013 ] {edb68584-a2fe-4533-a48c-5355536e2ba5} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1295, line 1298) (in query: SELECT synonyms(NULL, NULL, NULL);) 2025.06.13 15:58:03.032239 [ 45013 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.06.13 15:58:03.066613 [ 45013 ] {bb2f795b-e123-4555-ba73-e61a398bb32a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1296, line 1299) (in query: SELECT tan(NULL, NULL, NULL);) 2025.06.13 15:58:03.072119 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:03.097643 [ 45013 ] {11c6944f-c575-4d02-8466-2b6d2bbad927} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1297, line 1300) (in query: SELECT tanh(NULL, NULL, NULL);) 2025.06.13 15:58:03.102640 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:03.131507 [ 45013 ] {ea06fcdf-c573-47ec-b651-7f966ef4952f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1298, line 1301) (in query: SELECT tcpPort(NULL, NULL, NULL);) 2025.06.13 15:58:03.137701 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:03.170631 [ 45013 ] {4da68a35-b61a-4d9d-bd1d-8848630e131e} executeQuery: Code: 36. DB::Exception: Lambda x -> (x > 5) expect 1 arguments. Actual 3. In scope x -> (x > 5). (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1299, line 1302) (in query: SELECT test_3_function(NULL, NULL, NULL);) 2025.06.13 15:58:03.177131 [ 45013 ] {} TCPHandler: Code: 36. DB::Exception: Lambda x -> (x > 5) expect 1 arguments. Actual 3. In scope x -> (x > 5). (BAD_ARGUMENTS) 2025.06.13 15:58:03.213547 [ 45013 ] {39848a08-a63f-4e55-ab3e-0b1c15629fe6} executeQuery: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1300, line 1303) (in query: SELECT test_function(NULL, NULL, NULL);) 2025.06.13 15:58:03.221032 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:03.256828 [ 45013 ] {3f12cd72-2492-48c7-a653-a9d8186f841b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1301, line 1304) (in query: SELECT tgamma(NULL, NULL, NULL);) 2025.06.13 15:58:03.263960 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:03.735234 [ 45013 ] {484a2b9f-7689-4578-9708-bef4b5f81e91} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1304, line 1307) (in query: SELECT tid(NULL, NULL, NULL);) 2025.06.13 15:58:03.743782 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:03.860559 [ 45013 ] {b1eeae40-1d6c-431f-8e79-9ff5f4e953f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1305, line 1308) (in query: SELECT timeDiff(NULL, NULL, NULL);) 2025.06.13 15:58:03.872231 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:04.078489 [ 45013 ] {e38ab31a-b698-4a7d-9570-d24797a0192e} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1308, line 1311) (in query: SELECT timeZone(NULL, NULL, NULL);) 2025.06.13 15:58:04.086804 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:04.124430 [ 45013 ] {a41cd439-1e6c-4a9f-9c15-2ce5733316e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1309, line 1312) (in query: SELECT timeZoneOf(NULL, NULL, NULL);) 2025.06.13 15:58:04.131065 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:04.836660 [ 45013 ] {21a58d68-c6ee-40bd-946a-c72a54f7c5d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1315, line 1318) (in query: SELECT timezone(NULL, NULL, NULL);) 2025.06.13 15:58:04.843362 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:04.883184 [ 45013 ] {1ee354df-e71c-46f7-85e3-2860ac70a6dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1316, line 1319) (in query: SELECT timezoneOf(NULL, NULL, NULL);) 2025.06.13 15:58:04.895900 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:05.415385 [ 45013 ] {32822089-7192-47ca-b31a-bb85b9333beb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1321, line 1324) (in query: SELECT toBool(NULL, NULL, NULL);) 2025.06.13 15:58:05.421779 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:05.449560 [ 45013 ] {756b895c-839a-4b5d-b679-f2eafff6055f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1322, line 1325) (in query: SELECT toColumnTypeName(NULL, NULL, NULL);) 2025.06.13 15:58:05.454379 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:05.680236 [ 45013 ] {0abe4f97-1834-4784-a0c1-707827859f1c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1325, line 1328) (in query: SELECT toDate32OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:05.719463 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:05.917646 [ 45013 ] {a2e6aa19-d094-453e-bc86-23805c3656ec} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1328, line 1331) (in query: SELECT toDateOrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:05.924410 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:06.318573 [ 45013 ] {e05bb80b-3f69-4d9d-a7e7-020266cd3b30} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1334, line 1337) (in query: SELECT toDateTime64OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:06.326273 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:58:06.530503 [ 45013 ] {a029c7ac-c1cf-4536-9a14-1c58c6b87787} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1337, line 1340) (in query: SELECT toDateTimeOrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:06.538698 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:58:07.318602 [ 45013 ] {f6854067-4d2a-4ce1-9b32-fe0d71b81d28} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1345, line 1348) (in query: SELECT toDecimal128OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:07.337178 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:58:07.739383 [ 45013 ] {71ad1c65-cb0d-40a4-af04-fe9387186e6d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1349, line 1352) (in query: SELECT toDecimal256OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:07.797184 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:58:08.309289 [ 45013 ] {c38550da-4d87-4cb8-a29d-c14d4706f38f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1353, line 1356) (in query: SELECT toDecimal32OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:08.315124 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:58:08.565713 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:58:08.636023 [ 45013 ] {de82e8ea-2ddb-4ed3-95a2-c12b128459d1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1357, line 1360) (in query: SELECT toDecimal64OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:08.641774 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:58:08.776046 [ 45013 ] {65a6308a-4810-4ebf-b4a1-cb80b18b1fa3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1360, line 1363) (in query: SELECT toDecimalString(NULL, NULL, NULL);) 2025.06.13 15:58:08.781274 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:08.807197 [ 45013 ] {2f58341a-48ef-4e2f-b83a-b6b964bd01f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1361, line 1364) (in query: SELECT toFixedString(NULL, NULL, NULL);) 2025.06.13 15:58:08.814252 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:08.891444 [ 45013 ] {d964d7c3-ccb9-418e-acd9-acab4b73268c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1363, line 1366) (in query: SELECT toFloat32OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:08.897885 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:09.134792 [ 45013 ] {1313176c-82f1-4dc4-8b1b-cc3dc38d9bae} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1367, line 1370) (in query: SELECT toFloat64OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:09.142470 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:09.528070 [ 45013 ] {d94b5fc0-7405-4e4f-9f3e-de5c67c5ecde} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1372, line 1375) (in query: SELECT toIPv4OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:09.535377 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:09.965556 [ 45013 ] {88f6dbe2-a049-4a68-817e-240ecbbf0759} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1376, line 1379) (in query: SELECT toIPv6OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:09.973014 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:10.665314 [ 45013 ] {2288eae6-4155-43e3-b8e9-27f6fdb2119b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1382, line 1385) (in query: SELECT toInt128OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:10.672392 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:11.052938 [ 45013 ] {b68872cc-7af2-4603-8d46-958b1fca0545} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1386, line 1389) (in query: SELECT toInt16OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:11.078025 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:11.328104 [ 7279 ] {b928086f-aeb7-480d-b678-093f7501426c} executeQuery: Code: 81. DB::Exception: Database test_vufy6l0c_02911_keeper_map does not exist. Maybe you meant test_jn1gj4rw_02911_keeper_map?. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38886) (comment: 02911_backup_restore_keeper_map.sh) (query 1, line 1) (in query: SELECT count() FROM test_vufy6l0c_02911_keeper_map.02911_backup_restore_keeper_map1;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:681: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5eeb2d 6. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002d4aafbf 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000002d1345d3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1e5f4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4cbc1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:58:11.350956 [ 7279 ] {} TCPHandler: Code: 81. DB::Exception: Database test_vufy6l0c_02911_keeper_map does not exist. Maybe you meant test_jn1gj4rw_02911_keeper_map?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:681: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5eeb2d 6. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002d4aafbf 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000002d1345d3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1e5f4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4cbc1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:58:11.587062 [ 45013 ] {fdb6e8e6-b559-48cf-a8ae-deb087b89db0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1390, line 1393) (in query: SELECT toInt256OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:11.597913 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:11.769092 [ 7279 ] {1e74d09a-70c2-4e26-8ff5-8483bd96eded} executeQuery: Code: 81. DB::Exception: Database test_vufy6l0c_02911_keeper_map does not exist. Maybe you meant test_jn1gj4rw_02911_keeper_map?. (UNKNOWN_DATABASE) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:38900) (comment: 02911_backup_restore_keeper_map.sh) (query 1, line 1) (in query: SELECT count() FROM test_vufy6l0c_02911_keeper_map.02911_backup_restore_keeper_map2;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:681: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5eeb2d 6. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002d4aafbf 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000002d1345d3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1e5f4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4cbc1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:58:11.780660 [ 7279 ] {} TCPHandler: Code: 81. DB::Exception: Database test_vufy6l0c_02911_keeper_map does not exist. Maybe you meant test_jn1gj4rw_02911_keeper_map?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:681: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000002d5eeb2d 6. ./build_docker/./src/Interpreters/Context.cpp:5680: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x000000002d4aafbf 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:161: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000002d1345d3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000002cc1e5f4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4364: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4cbc1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5579: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9a01 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 21. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 22. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 27. ? @ 0x00007f2f4224dac3 28. ? @ 0x00007f2f422df850 2025.06.13 15:58:12.177951 [ 45013 ] {49325409-b0ca-47f6-95e1-d200453c7406} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1394, line 1397) (in query: SELECT toInt32OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:12.183681 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:12.637113 [ 45013 ] {06c15209-f714-4ad0-9f96-2ab2e25cf2ee} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1398, line 1401) (in query: SELECT toInt64OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:12.642388 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:12.735017 [ 18510 ] {01a97350-7da8-4456-92f2-64eac4d60dc4} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1139, line 380) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:58:12.744024 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:58:13.066295 [ 45013 ] {f9f5dbea-39c7-4e0b-a5e9-d05c72c1cdc8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1402, line 1405) (in query: SELECT toInt8OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:13.072470 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:14.188638 [ 45013 ] {1ca98187-5e5e-4e0f-85c5-b9eba5bde7d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1416, line 1419) (in query: SELECT toJSONString(NULL, NULL, NULL);) 2025.06.13 15:58:14.193628 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:14.345044 [ 45013 ] {d1716f64-2279-405c-bb16-361afc5ce02c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1419, line 1422) (in query: SELECT toLowCardinality(NULL, NULL, NULL);) 2025.06.13 15:58:14.349568 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:14.662697 [ 45013 ] {5249df3a-4fab-4fd6-90d1-8d585f8ed453} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1422, line 1425) (in query: SELECT toModifiedJulianDay(NULL, NULL, NULL);) 2025.06.13 15:58:14.677871 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:14.775646 [ 45013 ] {4086c941-0958-499a-8aae-fd025b2e479b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1423, line 1426) (in query: SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL);) 2025.06.13 15:58:14.783079 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:15.147455 [ 18510 ] {0809cba8-1a3f-4f0c-a8b1-706b913ad992} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 3.16 MiB (attempt to allocate chunk of 1.03 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1155, line 385) (in query: INSERT INTO mt_00763_2 SELECT toString(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b684b1 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032da7f6c 12. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: DB::MergeTreeDataPartWriterCompact::CompressedStream* std::construct_at[abi:ne190107]&, DB::MergeTreeDataPartWriterCompact::CompressedStream*>(DB::MergeTreeDataPartWriterCompact::CompressedStream*, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000030de357d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::allocator, 0>(std::allocator, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000030de321f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000030de30a0 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030ddef9d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030dd7e80 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd73ec 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dc188d 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c5a27a 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030feff3e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e43ccf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e3f751 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031229dad 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f67cf7 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f 2025.06.13 15:58:15.157266 [ 18510 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 3.16 MiB (attempt to allocate chunk of 1.03 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: 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&&) @ 0x0000000023ab5837 5. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3e67 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000023ab3846 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:77: CurrentMemoryTracker::allocImpl(long, bool) @ 0x00000000239927a9 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000023990de1 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000023b2c2db 10. ./src/IO/BufferWithOwnMemory.h:47: DB::BufferWithOwnMemory::BufferWithOwnMemory(unsigned long, char*, unsigned long) @ 0x0000000023b684b1 11. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:76: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000032da7f6c 12. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: DB::MergeTreeDataPartWriterCompact::CompressedStream* std::construct_at[abi:ne190107]&, DB::MergeTreeDataPartWriterCompact::CompressedStream*>(DB::MergeTreeDataPartWriterCompact::CompressedStream*, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000030de357d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::allocator, 0>(std::allocator, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000030de321f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000030de30a0 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000030ddef9d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c52801a 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002c528285 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000030dd7e80 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dd73ec 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030dc188d 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000030c5a27a 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x0000000030feff3e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000030e43ccf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030e3f751 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000031229dad 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000031f67cf7 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031dbc10b 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000031dbbd0b 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000031dbae61 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003182f92e 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003181ae5f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2990 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 10. ? @ 0x00007f2f4224dac3 11. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:58:15.231239 [ 45013 ] {ba5efb18-d56e-441a-9687-511ff2b2d785} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1427, line 1430) (in query: SELECT toNullable(NULL, NULL, NULL);) 2025.06.13 15:58:15.236111 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:17.690675 [ 45013 ] {7bda1f08-c5f0-47a6-9c2e-4823b0ab13f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1456, line 1459) (in query: SELECT toStringCutToZero(NULL, NULL, NULL);) 2025.06.13 15:58:17.714381 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:17.859974 [ 45013 ] {41e6e194-cfac-4394-807b-b9c70fd7b754} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1458, line 1461) (in query: SELECT toTimeZone(NULL, NULL, NULL);) 2025.06.13 15:58:17.866154 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:17.901212 [ 45013 ] {28c622a1-8d8a-4cf4-a1f7-4b03b3a99c94} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1459, line 1462) (in query: SELECT toTimezone(NULL, NULL, NULL);) 2025.06.13 15:58:17.953509 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:17.985858 [ 45013 ] {9ef2a0cc-7e33-4ce3-9bf3-59fba1c27f62} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1460, line 1463) (in query: SELECT toTypeName(NULL, NULL, NULL);) 2025.06.13 15:58:17.992324 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:18.162685 [ 45013 ] {f29b154b-1d46-4b92-ab68-44731e0df5be} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1462, line 1465) (in query: SELECT toUInt128OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:18.181313 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:18.470408 [ 45013 ] {c269d9bd-7133-4e05-b49d-887a22e70e30} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1466, line 1469) (in query: SELECT toUInt16OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:18.476104 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:18.759922 [ 45013 ] {93772773-5b3c-4157-9df5-e961cf8dfe2f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1470, line 1473) (in query: SELECT toUInt256OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:18.765620 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:18.977882 [ 45013 ] {137bf11d-80bf-4275-aa5f-8363fd5aadad} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1474, line 1477) (in query: SELECT toUInt32OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:18.983734 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:19.300116 [ 45013 ] {fa306165-b02c-4968-958a-233c0cc05d09} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1478, line 1481) (in query: SELECT toUInt64OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:19.304935 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:19.733702 [ 45013 ] {34848ef5-5010-44eb-994e-07e6aa2c59c6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1482, line 1485) (in query: SELECT toUInt8OrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:19.740594 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:20.055356 [ 45013 ] {9628d9c8-8777-4b3c-ae32-20e54bb7ea90} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1485, line 1488) (in query: SELECT toUTCTimestamp(NULL, NULL, NULL);) 2025.06.13 15:58:20.060810 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:20.249985 [ 45013 ] {9b627294-6c7a-465c-8b7a-f4269afeafcc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1487, line 1490) (in query: SELECT toUUIDOrDefault(NULL, NULL, NULL);) 2025.06.13 15:58:20.257040 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:20.648899 [ 45013 ] {9b529b55-dda7-4f47-964b-7d2ba797bae2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1491, line 1494) (in query: SELECT toUnixTimestamp64Micro(NULL, NULL, NULL);) 2025.06.13 15:58:20.670518 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:20.759632 [ 45013 ] {dc975f2a-68b4-48db-9c77-77842db68436} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1492, line 1495) (in query: SELECT toUnixTimestamp64Milli(NULL, NULL, NULL);) 2025.06.13 15:58:20.771444 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:20.868993 [ 45013 ] {dc5e3321-9a05-4810-8f20-4dddb2ae98f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1493, line 1496) (in query: SELECT toUnixTimestamp64Nano(NULL, NULL, NULL);) 2025.06.13 15:58:20.956202 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:21.077861 [ 45013 ] {37c16b46-aaa4-4162-a729-27c5ce95803d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Second(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1494, line 1497) (in query: SELECT toUnixTimestamp64Second(NULL, NULL, NULL);) 2025.06.13 15:58:21.105093 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Second(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:21.192473 [ 45013 ] {f54f2221-b6fa-4d6a-a716-27c5a5d9d327} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1495, line 1498) (in query: SELECT toValidUTF8(NULL, NULL, NULL);) 2025.06.13 15:58:21.207046 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:22.002940 [ 18510 ] {745d8009-a293-4641-9aaa-471fa5fcddce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1197, line 399) (in query: INSERT INTO mt_00763_2 SELECT toString(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:58:22.010397 [ 18510 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:58:23.101402 [ 45013 ] {3407f540-3242-4dff-993e-980cf6d653ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1503, line 1506) (in query: SELECT to_utc_timestamp(NULL, NULL, NULL);) 2025.06.13 15:58:23.125386 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:23.199503 [ 45013 ] {1e36f699-8b7e-489b-b06f-53036ff3979b} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1504, line 1507) (in query: SELECT today(NULL, NULL, NULL);) 2025.06.13 15:58:23.219034 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:23.296028 [ 45013 ] {2bf48bf7-7500-418a-a56a-2908d303609a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1505, line 1508) (in query: SELECT tokens(NULL, NULL, NULL);) 2025.06.13 15:58:23.308017 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:23.703894 [ 45013 ] {2b8cc18a-986d-42c5-9a24-c0c23484a85b} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1508, line 1511) (in query: SELECT topLevelDomain(NULL, NULL, NULL);) 2025.06.13 15:58:23.725064 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:23.772685 [ 45013 ] {f9f2fe54-fe82-4072-9224-8cd33a9c4d76} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1509, line 1512) (in query: SELECT topLevelDomainRFC(NULL, NULL, NULL);) 2025.06.13 15:58:23.778668 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:23.810770 [ 45013 ] {b277f475-709e-4907-941f-474360f7c64b} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1510, line 1513) (in query: SELECT transactionID(NULL, NULL, NULL);) 2025.06.13 15:58:23.816634 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:23.888934 [ 45013 ] {151cb395-de4f-4d95-b72c-e6cc0aa44f43} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1511, line 1514) (in query: SELECT transactionLatestSnapshot(NULL, NULL, NULL);) 2025.06.13 15:58:23.896321 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:23.958262 [ 45013 ] {ce2586de-f943-401b-be12-9f224c02467c} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1512, line 1515) (in query: SELECT transactionOldestSnapshot(NULL, NULL, NULL);) 2025.06.13 15:58:23.985240 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:24.030434 [ 45013 ] {85b870a3-2cf0-457b-91e0-a236af115022} executeQuery: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from: In scope SELECT transform(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1513, line 1516) (in query: SELECT transform(NULL, NULL, NULL);) 2025.06.13 15:58:24.038981 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from: In scope SELECT transform(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:58:24.099686 [ 18510 ] {c041bb23-ed5a-416e-be60-b9bd898ded8f} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1208, line 403) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:58:24.107116 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:58:24.881833 [ 8432 ] {aa2abcd0-b9b9-4f50-b432-14f472bdf4e8} executeQuery: Code: 36. DB::Exception: Query tree is too big. Maximum: 500000. (BAD_ARGUMENTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:46650) (comment: 00988_expansion_aliases_limit.sql) (query 1, line 1) (in query: SELECT 1 AS a, a + a AS b, b + b AS c, c + c AS d, d + d AS e, e + e AS f, f + f AS g, g + g AS h, h + h AS i, i + i AS j, j + j AS k, k + k AS l, l + l AS m, m + m AS n, n + n AS o, o + o AS p, p + p AS q, q + q AS r, r + r AS s, s + s AS t, t + t AS u, u + u AS v, v + v AS w, w + w AS x, x + x AS y, y + y AS z;), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. ./build_docker/./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>>>&) @ 0x000000002cc9c02e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3919: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0511a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:58:24.889848 [ 8432 ] {} 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. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000019effe4f 5. ./build_docker/./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>>>&) @ 0x000000002cc9c02e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3919: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002cc0511a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3979: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000002cc038df 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4303: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002cc4b7ac 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5590: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002cbf9aaf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002cbf76e9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002cbf6d11 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002cca3799 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002dd63e38 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002dd619fa 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002dd65dce 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000002dd65745 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002dccabcf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a1e60 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 20. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 21. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 26. ? @ 0x00007f2f4224dac3 27. ? @ 0x00007f2f422df850 2025.06.13 15:58:25.095464 [ 45013 ] {4b2dc2af-acbb-4be8-8ca0-f7d214317a72} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1521, line 1525) (in query: SELECT tryBase58Decode(NULL, NULL, NULL);) 2025.06.13 15:58:25.107539 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:25.177041 [ 45013 ] {16e5cb2b-d21f-47dd-ba95-9b4d68e07374} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1522, line 1526) (in query: SELECT tryBase64Decode(NULL, NULL, NULL);) 2025.06.13 15:58:25.190021 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:25.222481 [ 45013 ] {7cf5a85f-dc63-4bac-8001-7624b5ce1938} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1523, line 1527) (in query: SELECT tryBase64URLDecode(NULL, NULL, NULL);) 2025.06.13 15:58:25.227082 [ 18510 ] {b14fbfbe-b8a6-404f-a37b-1a681ebbe751} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1214, line 405) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:58:25.228397 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:25.233346 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:58:25.407367 [ 45013 ] {7531293c-fb1a-40ee-a4ca-ad29cbc31e0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1525, line 1529) (in query: SELECT tryIdnaEncode(NULL, NULL, NULL);) 2025.06.13 15:58:25.411947 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:25.480940 [ 45013 ] {08d0484b-369d-4dec-b127-44c2194ae031} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1526, line 1530) (in query: SELECT tryPunycodeDecode(NULL, NULL, NULL);) 2025.06.13 15:58:25.494912 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:26.156878 [ 45013 ] {5f431c69-d9ee-46af-be92-99a810fef9b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1532, line 1536) (in query: SELECT tupleDivide(NULL, NULL, NULL);) 2025.06.13 15:58:26.165147 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:26.197936 [ 45013 ] {80e0fdeb-2a32-4413-8b2b-795d60dd7936} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1533, line 1537) (in query: SELECT tupleDivideByNumber(NULL, NULL, NULL);) 2025.06.13 15:58:26.203738 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:26.241493 [ 45013 ] {b1ea27cd-9e0f-46aa-a928-76daef7f0f12} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1534, line 1538) (in query: SELECT tupleElement(NULL, NULL, NULL);) 2025.06.13 15:58:26.249190 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:58:26.345401 [ 45013 ] {524effc4-aa86-4da0-b3b0-c5deeafbf61a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1535, line 1539) (in query: SELECT tupleHammingDistance(NULL, NULL, NULL);) 2025.06.13 15:58:26.352489 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:26.384502 [ 45013 ] {967008ca-f4b3-4d05-a46c-ae928fb274fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1536, line 1540) (in query: SELECT tupleIntDiv(NULL, NULL, NULL);) 2025.06.13 15:58:26.391847 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:26.434022 [ 45013 ] {3f8688fc-704f-4571-bdf2-cf25a891768f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1537, line 1541) (in query: SELECT tupleIntDivByNumber(NULL, NULL, NULL);) 2025.06.13 15:58:26.501388 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:26.541249 [ 45013 ] {f3d664a8-6b75-4000-b877-f68570fa70f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1538, line 1542) (in query: SELECT tupleIntDivOrZero(NULL, NULL, NULL);) 2025.06.13 15:58:26.547531 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:26.589941 [ 45013 ] {ecebe19a-e9c6-4722-a77b-8c3f53fba250} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1539, line 1543) (in query: SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL);) 2025.06.13 15:58:26.597205 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:26.629358 [ 45013 ] {d6162fce-e241-4a91-b07f-285991cfab0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1540, line 1544) (in query: SELECT tupleMinus(NULL, NULL, NULL);) 2025.06.13 15:58:26.636874 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:26.773235 [ 45013 ] {acd28aa5-e977-45f1-9970-38c8426b7c69} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1541, line 1545) (in query: SELECT tupleModulo(NULL, NULL, NULL);) 2025.06.13 15:58:26.779413 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:26.814865 [ 45013 ] {5cf92411-bc5f-4765-8139-96ed950529f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1542, line 1546) (in query: SELECT tupleModuloByNumber(NULL, NULL, NULL);) 2025.06.13 15:58:26.822294 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:26.858059 [ 45013 ] {40b4bcb7-d428-47d4-81bf-8fce77b81e5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1543, line 1547) (in query: SELECT tupleMultiply(NULL, NULL, NULL);) 2025.06.13 15:58:26.863843 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:26.905770 [ 45013 ] {024bde30-3770-40c5-bbc5-77d11035224f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1544, line 1548) (in query: SELECT tupleMultiplyByNumber(NULL, NULL, NULL);) 2025.06.13 15:58:26.912016 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:26.954977 [ 45013 ] {f1f50f80-2d73-412f-a5fe-47cce08a3faa} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1545, line 1549) (in query: SELECT tupleNames(NULL, NULL, NULL);) 2025.06.13 15:58:26.971001 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:27.035830 [ 45013 ] {2effd1d9-d1de-4f33-8685-7ae8a121c570} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1546, line 1550) (in query: SELECT tupleNegate(NULL, NULL, NULL);) 2025.06.13 15:58:27.045365 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:27.104817 [ 45013 ] {05c803ac-ed36-4604-b63f-0a156f17f88b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1547, line 1551) (in query: SELECT tuplePlus(NULL, NULL, NULL);) 2025.06.13 15:58:27.117557 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:27.188271 [ 45013 ] {5e43152c-9a5f-4180-9733-3464f073658c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1548, line 1552) (in query: SELECT tupleToNameValuePairs(NULL, NULL, NULL);) 2025.06.13 15:58:27.208763 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:27.272169 [ 45013 ] {333ab9e5-8cf3-44f4-ae89-94f90e55e8a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1549, line 1553) (in query: SELECT ucase(NULL, NULL, NULL);) 2025.06.13 15:58:27.278628 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:27.320888 [ 45013 ] {3588fa63-19f3-4cd6-a8ef-582c291f7b3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1550, line 1554) (in query: SELECT unbin(NULL, NULL, NULL);) 2025.06.13 15:58:27.332961 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:27.440358 [ 45013 ] {19c7385e-88f5-4c62-85c1-fa3708621ab4} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1551, line 1555) (in query: SELECT unhex(NULL, NULL, NULL);) 2025.06.13 15:58:27.448150 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:27.965150 [ 18510 ] {d6049b13-e1b7-4658-aa74-9f7d24f8767d} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1232, line 411) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:58:27.971395 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:58:28.093331 [ 45013 ] {468f9cbc-3638-4886-a9f3-cde79da22a96} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1558, line 1562) (in query: SELECT uniqThetaIntersect(NULL, NULL, NULL);) 2025.06.13 15:58:28.099818 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:28.127422 [ 45013 ] {0e6490c8-88eb-4b73-9ccf-77dc4b68da26} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1559, line 1563) (in query: SELECT uniqThetaNot(NULL, NULL, NULL);) 2025.06.13 15:58:28.132740 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:28.161125 [ 45013 ] {5148af1f-7635-49c6-b615-39d56bbe1346} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1560, line 1564) (in query: SELECT uniqThetaUnion(NULL, NULL, NULL);) 2025.06.13 15:58:28.165816 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:28.281552 [ 45013 ] {5473c40f-bf93-46a8-ae89-126069c48124} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1562, line 1566) (in query: SELECT upper(NULL, NULL, NULL);) 2025.06.13 15:58:28.287999 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:28.316776 [ 45013 ] {40866130-ec1f-4b01-81e0-47b778c20565} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1563, line 1567) (in query: SELECT upperUTF8(NULL, NULL, NULL);) 2025.06.13 15:58:28.322302 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:28.356351 [ 45013 ] {b8474f4a-4484-4c79-9401-2ca9703f8ca8} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1564, line 1568) (in query: SELECT uptime(NULL, NULL, NULL);) 2025.06.13 15:58:28.361584 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:28.417078 [ 45013 ] {e162ef34-6e64-45c2-8d7f-de9d71be51bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1565, line 1569) (in query: SELECT user(NULL, NULL, NULL);) 2025.06.13 15:58:28.425004 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:28.829404 [ 45013 ] {01b8ec57-c734-411b-b216-5d4249bbd3f2} executeQuery: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1571, line 1575) (in query: SELECT variantElement(NULL, NULL, NULL);) 2025.06.13 15:58:28.834541 [ 45013 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.06.13 15:58:28.862613 [ 45013 ] {4645e4ff-3e65-4001-bf51-f205f557e200} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1572, line 1576) (in query: SELECT variantType(NULL, NULL, NULL);) 2025.06.13 15:58:28.869784 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:28.900032 [ 45013 ] {8021f73c-ce44-48a7-aca8-b24f095d4b78} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1573, line 1577) (in query: SELECT vectorDifference(NULL, NULL, NULL);) 2025.06.13 15:58:28.915430 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:29.040427 [ 45013 ] {94e650fc-d341-4ac4-b80d-4592d638ba43} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1574, line 1578) (in query: SELECT vectorSum(NULL, NULL, NULL);) 2025.06.13 15:58:29.050319 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:29.162371 [ 45013 ] {fce74d85-6946-44b9-ade9-436bf11090da} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1575, line 1579) (in query: SELECT version(NULL, NULL, NULL);) 2025.06.13 15:58:29.168992 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:29.219049 [ 45013 ] {e9b35ed7-0f02-4315-bfda-cd2489bc52e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1576, line 1580) (in query: SELECT visibleWidth(NULL, NULL, NULL);) 2025.06.13 15:58:29.232153 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:29.310428 [ 45013 ] {dcd7f7bb-370e-4567-b826-9ae540930e92} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1577, line 1581) (in query: SELECT visitParamExtractBool(NULL, NULL, NULL);) 2025.06.13 15:58:29.321730 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:29.482030 [ 45013 ] {3c9bcd25-1b01-4fb0-a238-4bfa3e42a010} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1578, line 1582) (in query: SELECT visitParamExtractFloat(NULL, NULL, NULL);) 2025.06.13 15:58:29.491868 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:29.641625 [ 45013 ] {355c6a35-d1fc-48d6-b3fa-33a9ebfb8dd0} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1579, line 1583) (in query: SELECT visitParamExtractInt(NULL, NULL, NULL);) 2025.06.13 15:58:29.654205 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:29.696598 [ 45013 ] {fa299189-2a2d-4c6b-a900-b64af4c1fa08} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1580, line 1584) (in query: SELECT visitParamExtractRaw(NULL, NULL, NULL);) 2025.06.13 15:58:29.705614 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:29.745927 [ 45013 ] {f36dba62-211b-4639-b46d-4798190bdeab} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1581, line 1585) (in query: SELECT visitParamExtractString(NULL, NULL, NULL);) 2025.06.13 15:58:29.753561 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:29.866509 [ 45013 ] {6dc257d6-77c0-48c2-b0b4-cb76ab83171a} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1582, line 1586) (in query: SELECT visitParamExtractUInt(NULL, NULL, NULL);) 2025.06.13 15:58:29.875892 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:29.932775 [ 45013 ] {c4b728a0-4cf1-48b5-b926-de85475cc4b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1583, line 1587) (in query: SELECT visitParamHas(NULL, NULL, NULL);) 2025.06.13 15:58:29.937925 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:30.217096 [ 45013 ] {7b098eab-dcf2-46b4-becd-9ea594d43a9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1586, line 1590) (in query: SELECT widthBucket(NULL, NULL, NULL);) 2025.06.13 15:58:30.225449 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:30.255124 [ 45013 ] {62a3101e-6f9e-495f-bf0f-3fc938f47566} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1587, line 1591) (in query: SELECT width_bucket(NULL, NULL, NULL);) 2025.06.13 15:58:30.270235 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:30.642573 [ 45013 ] {f9b9da36-e07b-4d3d-b2c9-4ec0203ca814} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1590, line 1594) (in query: SELECT wkt(NULL, NULL, NULL);) 2025.06.13 15:58:30.647671 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:31.577082 [ 18510 ] {8be9b8a5-aa98-417d-98c2-15da2c44d26a} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1256, line 419) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:58:31.592068 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:58:32.437364 [ 45013 ] {cca061b8-b656-4cf3-971a-c097f7877d6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1608, line 1612) (in query: SELECT yandexConsistentHash(NULL, NULL, NULL);) 2025.06.13 15:58:32.443920 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:32.540771 [ 45013 ] {bdf32938-8287-440f-9e36-40590a382fe5} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1610, line 1614) (in query: SELECT yesterday(NULL, NULL, NULL);) 2025.06.13 15:58:32.548732 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:32.615230 [ 45013 ] {e8897e20-6f75-4c85-8c86-47a87f2229e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:42250) (comment: 00534_functions_bad_arguments11.sh) (query 1611, line 1615) (in query: SELECT zookeeperSessionUptime(NULL, NULL, NULL);) 2025.06.13 15:58:32.634636 [ 45013 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.06.13 15:58:34.313492 [ 18510 ] {11669c36-6129-4257-a08c-4806d7e00f84} 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.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1272, line 424) (in query: INSERT INTO mt_00763_2 SELECT toString(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 2025.06.13 15:58:34.368036 [ 18510 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc2f8b 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003181c1f2 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000031819f71 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000031819a2a 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000318185fb 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 13. ? @ 0x00007f2f4224dac3 14. ? @ 0x00007f2f422df850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000023adb963 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000023bbd1b8 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bbf390 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000023bbfad6 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x0000000031817b2d 5. ./build_docker/./src/Server/TCPHandler.cpp:706: DB::TCPHandler::runImpl() @ 0x00000000316a48a0 6. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 11. ? @ 0x00007f2f4224dac3 12. ? @ 0x00007f2f422df850 2025.06.13 15:58:36.696337 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:59:35.396550 [ 18510 ] {c71cc85c-31a1-453d-bd62-77dccfa65d43} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1304, line 435) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:35.410909 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:36.083702 [ 18510 ] {fe23a288-4010-4960-844b-d4d9ed1e1f18} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1310, line 437) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:36.098981 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:36.978707 [ 18510 ] {468f2b32-98d0-4eea-beae-d7de9957b055} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1316, line 439) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:36.986022 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:42.067184 [ 18510 ] {faaa473d-c72d-4b4e-a1f8-06ebd1c19f7a} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1349, line 450) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:42.073564 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:43.355995 [ 18510 ] {73f4e0d2-9490-467a-976f-45cc6db4cc2e} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1361, line 454) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:43.362392 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:44.337680 [ 18510 ] {0688bb05-edda-4874-81a6-87527e830c1f} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1370, line 457) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:44.344759 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:45.431108 [ 18510 ] {e0332604-f42a-4a99-8d80-50ae109e7858} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1379, line 460) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:45.438101 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:45.728058 [ 18510 ] {7c641b1d-bb03-46cc-af6e-99d2ca3ed5c1} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1382, line 461) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:45.735048 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:46.809481 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 15:59:47.304185 [ 18510 ] {efb15155-c055-4baf-8d71-f0fe33e4d6a2} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1391, line 464) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:47.315247 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:47.852141 [ 18510 ] {ee6f56e1-de97-44fa-97e8-75aac7762222} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1394, line 465) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:47.860503 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:51.063080 [ 18510 ] {de991451-babc-4ad4-b010-b569b0f5cbf4} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1415, line 472) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:51.069576 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:51.268093 [ 18510 ] {53c30818-8832-4e14-ad54-db2d39e4842d} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1418, line 473) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:51.274997 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:54.812193 [ 18510 ] {31314f5a-db4e-42c6-a3a4-71bcc3fc1cc8} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1442, line 481) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:54.819190 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:55.613388 [ 18510 ] {e8133b73-75d1-4c9a-95ca-e1bb5cd23f7e} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1448, line 483) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:55.624992 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:57.486198 [ 18510 ] {a2beebcc-ada0-4f5c-a08b-243ab9782e9b} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1460, line 487) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:57.492843 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:57.747673 [ 18510 ] {60b6741a-155a-42f9-8cbd-e6efe50886c9} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1463, line 488) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:57.755160 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:58.583522 [ 18510 ] {0dbba3ef-849a-4cc7-aefe-199f2334e48b} executeQuery: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.3.20286.altinityantalya (altinity build)) (from [::1]:48576) (comment: 00763_lock_buffer_long.sh) (query 1469, line 490) (in query: CREATE TABLE mt_00763_2 (`s` String) ENGINE = MergeTree ORDER BY s SETTINGS index_granularity = 54178, min_bytes_for_wide_part = 1055598003, ratio_of_defaults_for_sparse_serialization = 0.7696163654327393, replace_long_file_name_to_hash = true, max_file_name_length = 120, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 189859430, compact_parts_max_granules_to_buffer = 216, compact_parts_merge_max_bytes_to_prefetch_part = 3819465, merge_max_block_size = 19507, 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 = 4828231, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 44, 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 = 22438, primary_key_compress_block_size = 93005, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 15:59:58.594725 [ 18510 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.mt_00763_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000017cbe0af 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1823: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000002dc8107c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000002dc72a6c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2344: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897e5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000002e29cabb 10. ./build_docker/./src/Server/TCPHandler.cpp:663: DB::TCPHandler::runImpl() @ 0x00000000316a42bc 11. ./build_docker/./src/Server/TCPHandler.cpp:2628: DB::TCPHandler::run() @ 0x00000000316d3b2e 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 16. ? @ 0x00007f2f4224dac3 17. ? @ 0x00007f2f422df850 2025.06.13 16:00:06.629487 [ 3497 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fb841949-1f90-4e7f-a94f-b2b9aa4ee8db::202506_1_186_58}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab57af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab1fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003122f56b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d8e4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:00:35.053403 [ 2868 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' (skipped 5757 similar messages) 2025.06.13 16:01:06.875968 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:02:31.533666 [ 3510 ] {0d1b968b-968f-4ab8-a5f8-7fab70495fd4::202506_1_237_92} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c14c18 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c06f6e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:02:31.536675 [ 3510 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0d1b968b-968f-4ab8-a5f8-7fab70495fd4::202506_1_237_92}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c14c18 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c06f6e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:02:37.042820 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:03:24.765680 [ 3511 ] {0d1b968b-968f-4ab8-a5f8-7fab70495fd4::202506_1_244_99} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c14c18 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c06f6e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:03:24.768275 [ 3511 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0d1b968b-968f-4ab8-a5f8-7fab70495fd4::202506_1_244_99}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x0000000023bc9a5a 5. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000023bc26c9 6. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000023bc2496 7. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000030efc4e6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000030ef7c11 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000030ef79e7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000030f275f3 11. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000030dc7061 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000030dc15ab 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&)::$_0::operator()(DB::NamesAndTypesList const&, bool) const @ 0x0000000030f6db41 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:74: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000030f6d6eb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000030f61d41 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6c4de 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, std::allocator, 0>(std::allocator, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6bfd8 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::optional, bool&, bool&, 0>(std::allocator const&, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000030f6be25 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000030f658b1 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:383: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000030f6919d 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x00000000321150df 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003216431a 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x0000000030c14c18 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x0000000030c06f6e 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000030c18197 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x0000000030c26259 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d93c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:03:55.396806 [ 3509 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0d1b968b-968f-4ab8-a5f8-7fab70495fd4::202506_1_248_103}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x0000000023ab57af 5. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x0000000023ab1fd9 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003122f56b 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003122d8e4 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000030c6791d 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000030c68654 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bc0b38 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000023bc9474 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 14. ? @ 0x00007f2f4224dac3 15. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:04:17.205396 [ 4098 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002beaae6f 5. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002beaa4bc 6. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002bea92b6 7. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002bea974e 8. ./build_docker/./src/Interpreters/Context.cpp:2694: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48890c 9. ./build_docker/./src/Interpreters/Context.cpp:2733: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002d48923f 10. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6157 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 17. ? @ 0x00007f2f4224dac3 18. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:05:21.738769 [ 4098 ] {0c85e902-6eb3-407d-a24a-68a042de51dd} 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.20286.altinityantalya (altinity build)) (from [::1]:46848) (in query: CREATE DATABASE IF NOT EXISTS test ), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:216: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000002c701d3a 5. ./build_docker/./src/Common/atomicRename.cpp:94: DB::renameat2(String const&, String const&, int) @ 0x000000002c701af1 6. ./build_docker/./src/Common/atomicRename.cpp:227: DB::renameNoReplace(String const&, String const&) @ 0x000000002c7015c7 7. ./build_docker/./src/Disks/DiskLocal.cpp:318: DB::DiskLocal::moveFile(String const&, String const&) @ 0x000000002c93d897 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:395: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc5517f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 2025.06.13 16:05:21.739411 [ 4098 ] {0c85e902-6eb3-407d-a24a-68a042de51dd} DynamicQueryHandler: Code: 521. DB::ErrnoException: Cannot rename /var/lib/clickhouse/metadata/test.sql.tmp to /var/lib/clickhouse/metadata/test.sql because the second path already exists: , errno: 17, strerror: File exists. (ATOMIC_RENAME_FAIL), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:216: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000002c701d3a 5. ./build_docker/./src/Common/atomicRename.cpp:94: DB::renameat2(String const&, String const&, int) @ 0x000000002c701af1 6. ./build_docker/./src/Common/atomicRename.cpp:227: DB::renameNoReplace(String const&, String const&) @ 0x000000002c7015c7 7. ./build_docker/./src/Disks/DiskLocal.cpp:318: DB::DiskLocal::moveFile(String const&, String const&) @ 0x000000002c93d897 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:395: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002dc5517f 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2343: DB::InterpreterCreateQuery::execute() @ 0x000000002dc897c6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000002e2a2b74 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000002e2a8590 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x00000000315b6e07 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000315bc5eb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x00000000316e89cc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000035ac1582 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000035ac2252 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000035a2afb7 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000035a269ae 19. ? @ 0x00007f2f4224dac3 20. ? @ 0x00007f2f422df850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:05:24.937694 [ 2857 ] {} Application: Closed all listening sockets. Waiting for 20 outstanding connections. 2025.06.13 16:05:29.844345 [ 2857 ] {} Application: Closed connections. But 20 remain. Tip: To increase wait time add to config: 60 2025.06.13 16:05:29.844450 [ 2857 ] {} Application: Will shutdown forcefully. 2025.06.13 16:05:31.669042 [ 56026 ] {} Context: Server was built with undefined behavior sanitizer. It will work slowly. 2025.06.13 16:05:32.074110 [ 56033 ] {} CgroupsReader: Cannot find 'kernel' in '/sys/fs/cgroup/memory.stat' 2025.06.13 16:05:32.344072 [ 56026 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.06.13 16:05:32.346511 [ 56026 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.06.13 16:05:32.346523 [ 56026 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.06.13 16:05:32.397827 [ 56614 ] {} RaftInstance: Election timeout, initiate leader election 2025.06.13 16:05:33.275043 [ 56026 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.06.13 16:05:33.275438 [ 56026 ] {} 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.06.13 16:05:33.275807 [ 56026 ] {} 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.06.13 16:05:43.036469 [ 56828 ] {} system.transactions_info_log (0d1b968b-968f-4ab8-a5f8-7fab70495fd4): Removing temporary directory /var/lib/clickhouse/store/0d1/0d1b968b-968f-4ab8-a5f8-7fab70495fd4/tmp_insert_202506_241_241_0/ 2025.06.13 16:05:44.556764 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_aehnkacf.sql.tmp 2025.06.13 16:05:44.556868 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_e0139opk.sql.tmp 2025.06.13 16:05:44.556924 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_tdywopmn.sql.tmp 2025.06.13 16:05:44.556977 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_hemdhimm.sql.tmp 2025.06.13 16:05:44.557029 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_g8z453f2.sql.tmp 2025.06.13 16:05:44.557119 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_ixb3v01f.sql.tmp 2025.06.13 16:05:44.557190 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_oxscdzfx.sql.tmp 2025.06.13 16:05:44.557265 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_l0ur20mz.sql.tmp 2025.06.13 16:05:44.557345 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_u0oa32ag.sql.tmp 2025.06.13 16:05:44.557418 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_wrnj8dwa.sql.tmp 2025.06.13 16:05:44.557475 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_0w44qv1x.sql.tmp 2025.06.13 16:05:44.557529 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_ezb9fhd4.sql.tmp 2025.06.13 16:05:44.557605 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_qkrvynfo.sql.tmp 2025.06.13 16:05:44.557662 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_bp2t28pz.sql.tmp 2025.06.13 16:05:44.557718 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_53je454m.sql.tmp 2025.06.13 16:05:44.557788 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_j7jew2i8.sql.tmp 2025.06.13 16:05:44.557840 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_2q8ine2x.sql.tmp 2025.06.13 16:05:44.557886 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_epv1did5.sql.tmp 2025.06.13 16:05:44.557940 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_sv8xv4p5.sql.tmp 2025.06.13 16:05:44.557985 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_2vv406sy.sql.tmp 2025.06.13 16:05:44.558030 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_1i57e2td.sql.tmp 2025.06.13 16:05:44.558092 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_vh3qjf9w.sql.tmp 2025.06.13 16:05:44.558138 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_qnddyzgy.sql.tmp 2025.06.13 16:05:44.558197 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_mgc38zrp.sql.tmp 2025.06.13 16:05:44.558241 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_wpjx74ex.sql.tmp 2025.06.13 16:05:44.558286 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_v1yow8s7.sql.tmp 2025.06.13 16:05:44.558350 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_u8tasey8.sql.tmp 2025.06.13 16:05:44.558415 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_j722qx2w.sql.tmp 2025.06.13 16:05:44.558470 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_9sxizitc.sql.tmp 2025.06.13 16:05:44.558527 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_6c4itfo5.sql.tmp 2025.06.13 16:05:44.558596 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_sik7xe2i.sql.tmp 2025.06.13 16:05:44.558648 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_i1q90s1d.sql.tmp 2025.06.13 16:05:44.558703 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_l7djhgyx.sql.tmp 2025.06.13 16:05:44.558748 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_fxcv9mzu.sql.tmp 2025.06.13 16:05:44.558790 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_46e4f5sl.sql.tmp 2025.06.13 16:05:44.558833 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_jm1cka07.sql.tmp 2025.06.13 16:05:44.558878 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_viii640k.sql.tmp 2025.06.13 16:05:44.558947 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_54mq9f8c.sql.tmp 2025.06.13 16:05:44.558996 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_7s3h9pb7.sql.tmp 2025.06.13 16:05:44.559040 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_d0uwlyzv.sql.tmp 2025.06.13 16:05:44.559085 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_c7a7u4qn.sql.tmp 2025.06.13 16:05:44.559140 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_x3006r63.sql.tmp 2025.06.13 16:05:44.559212 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_s0l3pf3s.sql.tmp 2025.06.13 16:05:44.559258 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_rsfoq6sa.sql.tmp 2025.06.13 16:05:44.559304 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_du6d4cxg.sql.tmp 2025.06.13 16:05:44.559352 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_yozptp7k.sql.tmp 2025.06.13 16:05:44.559403 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_t322rusm.sql.tmp 2025.06.13 16:05:44.559447 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_9v0g1pqv.sql.tmp 2025.06.13 16:05:44.559490 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_2l1t1wxt.sql.tmp 2025.06.13 16:05:44.559532 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_1whjtbk0.sql.tmp 2025.06.13 16:05:44.559575 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_smu3nb27.sql.tmp 2025.06.13 16:05:44.559633 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_zhj2jp6h.sql.tmp 2025.06.13 16:05:44.559688 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_h50dsuj1.sql.tmp 2025.06.13 16:05:44.559732 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_8ashox2t.sql.tmp 2025.06.13 16:05:44.559775 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_3shcr6ye.sql.tmp 2025.06.13 16:05:44.559836 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_8dm6ckum.sql.tmp 2025.06.13 16:05:44.559880 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_hzt5fplf.sql.tmp 2025.06.13 16:05:44.559923 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_7ssrb2jq.sql.tmp 2025.06.13 16:05:44.559965 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_fyw8sox2.sql.tmp 2025.06.13 16:05:44.560022 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_lk3q8mxz.sql.tmp 2025.06.13 16:05:44.560101 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_pgfvpgz0.sql.tmp 2025.06.13 16:05:44.560192 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_g6fh2pfu.sql.tmp 2025.06.13 16:05:44.560247 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_zaxc6sv7.sql.tmp 2025.06.13 16:05:44.560293 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_pazamned.sql.tmp 2025.06.13 16:05:44.560355 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_en2kcfs5.sql.tmp 2025.06.13 16:05:44.560422 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test.sql.tmp 2025.06.13 16:05:44.560471 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_32vzquk9.sql.tmp 2025.06.13 16:05:44.560515 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_l9vp7deb.sql.tmp 2025.06.13 16:05:44.560560 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_1sdj6reg.sql.tmp 2025.06.13 16:05:44.560632 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_xznpyyo5.sql.tmp 2025.06.13 16:05:44.560684 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_4so2yqb9.sql.tmp 2025.06.13 16:05:44.560782 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_tslx1c0c.sql.tmp 2025.06.13 16:05:44.560829 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_osocl6xn.sql.tmp 2025.06.13 16:05:44.560886 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_wfrde4rf.sql.tmp 2025.06.13 16:05:44.560949 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_2p120kvt.sql.tmp 2025.06.13 16:05:44.560997 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_nbpmie94.sql.tmp 2025.06.13 16:05:44.561061 [ 56026 ] {} loadMetadata: Removing temporary file metadata/test_xonb2e8j.sql.tmp 2025.06.13 16:05:44.649255 [ 56026 ] {} TablesLoader: Tables test_9.dist_01072 depend on default.key, but seems like that does not exist. Will ignore it and try to load existing tables 2025.06.13 16:05:44.896619 [ 56833 ] {} DDLWorker(test_ytp1isnr_db): Replica seems to be lost: our_log_ptr=5, max_log_ptr=5, local_digest=6849973880316836156, zk_digest=10500214101715060315 2025.06.13 16:05:44.896713 [ 56833 ] {} DatabaseReplicated (test_ytp1isnr_db): Will recover replica with staled log pointer 5 from log pointer 5 2025.06.13 16:05:44.896730 [ 56967 ] {} DDLWorker(test_dykw4rlt_db): Replica seems to be lost: our_log_ptr=5, max_log_ptr=5, local_digest=17781364879409050108, zk_digest=4793053536578030745 2025.06.13 16:05:44.896891 [ 56967 ] {} DatabaseReplicated (test_dykw4rlt_db): Will recover replica with staled log pointer 5 from log pointer 5 2025.06.13 16:05:44.896952 [ 56810 ] {} DDLWorker(test_11): Replica seems to be lost: our_log_ptr=101, max_log_ptr=101, local_digest=18415650798873536672, zk_digest=16041845121538657332 2025.06.13 16:05:44.897204 [ 56810 ] {} DatabaseReplicated (test_11): Will recover replica with staled log pointer 101 from log pointer 101 2025.06.13 16:05:45.501770 [ 56853 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Session expired (fault injected on recv). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x0000000031173f2d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x0000000031173e22 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1787: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000003281a020 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:927: Coordination::ZooKeeper::receiveEvent() @ 0x0000000032817d52 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:874: Coordination::ZooKeeper::receiveThread() @ 0x0000000032816c4f 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:452: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000032823e9e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 11. ? @ 0x00007f8718401ac3 12. ? @ 0x00007f8718493850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:05:45.502456 [ 56122 ] {} test_13.replicated_mutations_empty_partitions (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.502547 [ 56142 ] {} test_13.enum_alter_issue (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.502609 [ 56140 ] {} test_ww6mlyc5.rename2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.502689 [ 56134 ] {} test_3.wrong_metadata (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.502752 [ 56139 ] {} test_nkpekc8y.keeper_retries_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.502852 [ 56143 ] {} test_zmookgdx.table_for_rename1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.502942 [ 56133 ] {} test_i0frc2hu.table_for_rename_pk (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.502992 [ 56137 ] {} test_dykw4rlt_db.`.inner_id.d731a23c-fd48-4eaf-9508-374b96b05c07` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.503056 [ 56136 ] {} test_rov98m53.r_prop_table1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.503243 [ 56144 ] {} test_11jn31ss.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.503631 [ 56145 ] {} test_3.mt_compact (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.503656 [ 56146 ] {} test_3.replicated_truncate2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.503686 [ 56147 ] {} test_ytp1isnr_db.`.inner_id.2ce45d9d-8080-4fec-95ea-b4be0300ce7d` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.503984 [ 56149 ] {} test_ww6mlyc5.rename1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.504106 [ 56130 ] {} test_41tvivz0.minmax_idx_r (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.504216 [ 56148 ] {} test_3.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.504317 [ 56150 ] {} test_9.replicated_report (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.504518 [ 56151 ] {} test_3.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.504776 [ 56152 ] {} test_nkpekc8y.keeper_retries_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.504821 [ 56154 ] {} test_11jn31ss.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.504970 [ 56153 ] {} test_dykw4rlt_db.`.inner_id.2c5163bb-b677-4854-9a23-662865d79323` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.504997 [ 56155 ] {} test_13.`02784_async_table_with_dedup` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.505007 [ 56156 ] {} test_13.sample_table_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.505120 [ 56157 ] {} test_41tvivz0.minmax_idx (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.505132 [ 56158 ] {} test_13.tp_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.505326 [ 56159 ] {} test_3.replicated_numbers (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.505572 [ 56160 ] {} test_1.wrong_metadata (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.505658 [ 56162 ] {} test_ytp1isnr_db.`.inner_id.62988215-acf7-4b03-89dd-b62c291d6010` (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.505745 [ 56161 ] {} test_rov98m53.r_prop_table2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.505755 [ 56163 ] {} test_27nvrbto.rmt (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.505852 [ 56165 ] {} test_1.wrong_metadata_compact (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.505940 [ 56164 ] {} test_zcudb9ph.quorum2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.506048 [ 56166 ] {} test_zcudb9ph.quorum1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.06.13 16:05:45.546517 [ 56126 ] {} test_27nvrbto.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02253/02253_empty_part_checksums_test_27nvrbto/rmt/blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000001af98c7c 5. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000001af984d0 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x0000000032755b6f 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:347: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003275556c 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:547: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x00000000310c99bc 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:477: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x00000000310c34db 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:194: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x00000000310be13d 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000310bc942 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 17. ? @ 0x00007f8718401ac3 18. ? @ 0x00007f8718493850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:05:45.584531 [ 56454 ] {} test_27nvrbto.rmt (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x00000000327b732d 4. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000327a0b42 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1299: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003281b2a6 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1479: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000003282040b 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1290: zkutil::ZooKeeper::asyncTryExistsNoThrow(String const&, std::function) @ 0x000000003275947e 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:561: zkutil::ZooKeeper::existsImpl(String const&, Coordination::Stat*, std::function) @ 0x0000000032758f57 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:595: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x0000000032759716 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:579: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x0000000032756778 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:235: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x00000000310bf7a6 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x00000000310be0bd 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000310bc942 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c07380c 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002c077b17 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002c078b66 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000023bbdd4f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000023bc59ea 19. ? @ 0x00007f8718401ac3 20. ? @ 0x00007f8718493850 (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:06:05.088601 [ 57213 ] {} DiskLocal: Cannot gain read access of the disk directory: disk1_02961/ 2025.06.13 16:06:05.212135 [ 57213 ] {} DiskLocal: Disk disk1_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk1_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b10560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1045e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1a868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c949f32 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c94beb6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c95a742 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c94ce82 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9752ac 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4a3d3b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4a4316 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4a4f02 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47026d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7c1d3c 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c70d9e3 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d60c861 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d60c63f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d60c466 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5e6215 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4de44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e46517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b0ba7b 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e599b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb1ba8 29. ? @ 0x00007fe1cdb41d90 30. ? @ 0x00007fe1cdb41e40 31. _start @ 0x0000000017c9702e (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:06:05.212467 [ 57213 ] {} DiskLocal: Cannot gain read access of the disk directory: disk2_02961/ 2025.06.13 16:06:05.212512 [ 57213 ] {} DiskLocal: Disk disk2_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk2_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b10560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1045e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1a868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c949f32 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c94beb6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c95a742 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c94ce82 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9752ac 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4a3d3b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4a4316 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4a4f02 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47026d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7c1d3c 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c70d9e3 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d60c861 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d60c63f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d60c466 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5e6215 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4de44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e46517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b0ba7b 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e599b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb1ba8 29. ? @ 0x00007fe1cdb41d90 30. ? @ 0x00007fe1cdb41e40 31. _start @ 0x0000000017c9702e (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:06:05.212638 [ 57213 ] {} DiskLocal: Cannot gain read access of the disk directory: disk3_02961/ 2025.06.13 16:06:05.212673 [ 57213 ] {} DiskLocal: Disk disk3_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk3_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b10560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1045e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1a868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c949f32 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c94beb6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c95a742 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c94ce82 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9752ac 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4a3d3b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4a4316 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4a4f02 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47026d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7c1d3c 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c70d9e3 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d60c861 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d60c63f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d60c466 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5e6215 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4de44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e46517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b0ba7b 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e599b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb1ba8 29. ? @ 0x00007fe1cdb41d90 30. ? @ 0x00007fe1cdb41e40 31. _start @ 0x0000000017c9702e (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:06:05.212778 [ 57213 ] {} DiskLocal: Cannot gain read access of the disk directory: disk4_02961/ 2025.06.13 16:06:05.212812 [ 57213 ] {} DiskLocal: Disk disk4_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk4_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b10560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1045e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1a868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c949f32 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c94beb6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c95a742 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c94ce82 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9752ac 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4a3d3b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4a4316 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4a4f02 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47026d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7c1d3c 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c70d9e3 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d60c861 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d60c63f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d60c466 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5e6215 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4de44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e46517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b0ba7b 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e599b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb1ba8 29. ? @ 0x00007fe1cdb41d90 30. ? @ 0x00007fe1cdb41e40 31. _start @ 0x0000000017c9702e (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:06:19.974931 [ 57910 ] {} DiskLocal: Cannot gain read access of the disk directory: disk1_02961/ 2025.06.13 16:06:20.080119 [ 57910 ] {} DiskLocal: Disk disk1_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk1_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b10560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1045e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1a868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c949f32 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c94beb6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c95a742 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c94ce82 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9752ac 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4a3d3b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4a4316 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4a4f02 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47026d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7c1d3c 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c70d9e3 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d60c861 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d60c63f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d60c466 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5e6215 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4de44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e46517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b0ba7b 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e599b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb1ba8 29. ? @ 0x00007f94d6978d90 30. ? @ 0x00007f94d6978e40 31. _start @ 0x0000000017c9702e (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:06:20.080452 [ 57910 ] {} DiskLocal: Cannot gain read access of the disk directory: disk2_02961/ 2025.06.13 16:06:20.080512 [ 57910 ] {} DiskLocal: Disk disk2_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk2_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b10560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1045e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1a868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c949f32 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c94beb6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c95a742 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c94ce82 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9752ac 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4a3d3b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4a4316 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4a4f02 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47026d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7c1d3c 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c70d9e3 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d60c861 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d60c63f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d60c466 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5e6215 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4de44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e46517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b0ba7b 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e599b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb1ba8 29. ? @ 0x00007f94d6978d90 30. ? @ 0x00007f94d6978e40 31. _start @ 0x0000000017c9702e (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:06:20.080645 [ 57910 ] {} DiskLocal: Cannot gain read access of the disk directory: disk3_02961/ 2025.06.13 16:06:20.080692 [ 57910 ] {} DiskLocal: Disk disk3_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk3_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b10560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1045e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1a868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c949f32 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c94beb6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c95a742 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c94ce82 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9752ac 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4a3d3b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4a4316 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4a4f02 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47026d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7c1d3c 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c70d9e3 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d60c861 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d60c63f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d60c466 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5e6215 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4de44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e46517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b0ba7b 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e599b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb1ba8 29. ? @ 0x00007f94d6978d90 30. ? @ 0x00007f94d6978e40 31. _start @ 0x0000000017c9702e (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:06:20.080938 [ 57910 ] {} DiskLocal: Cannot gain read access of the disk directory: disk4_02961/ 2025.06.13 16:06:20.080979 [ 57910 ] {} DiskLocal: Disk disk4_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk4_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b10560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1045e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1a868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c949f32 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c94beb6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c95a742 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c94ce82 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9752ac 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4a3d3b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4a4316 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4a4f02 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47026d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7c1d3c 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c70d9e3 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d60c861 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d60c63f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d60c466 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5e6215 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4de44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e46517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b0ba7b 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e599b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb1ba8 29. ? @ 0x00007f94d6978d90 30. ? @ 0x00007f94d6978e40 31. _start @ 0x0000000017c9702e (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:06:34.703461 [ 58611 ] {} DiskLocal: Cannot gain read access of the disk directory: disk1_02961/ 2025.06.13 16:06:34.831817 [ 58611 ] {} DiskLocal: Disk disk1_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk1_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b10560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1045e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1a868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c949f32 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c94beb6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c95a742 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c94ce82 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9752ac 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4a3d3b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4a4316 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4a4f02 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47026d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7c1d3c 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c70d9e3 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d60c861 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d60c63f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d60c466 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5e6215 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4de44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e46517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b0ba7b 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e599b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb1ba8 29. ? @ 0x00007f46d88c6d90 30. ? @ 0x00007f46d88c6e40 31. _start @ 0x0000000017c9702e (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:06:34.832133 [ 58611 ] {} DiskLocal: Cannot gain read access of the disk directory: disk2_02961/ 2025.06.13 16:06:34.832176 [ 58611 ] {} DiskLocal: Disk disk2_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk2_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b10560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1045e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1a868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c949f32 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c94beb6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c95a742 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c94ce82 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9752ac 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4a3d3b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4a4316 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4a4f02 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47026d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7c1d3c 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c70d9e3 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d60c861 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d60c63f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d60c466 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5e6215 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4de44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e46517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b0ba7b 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e599b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb1ba8 29. ? @ 0x00007f46d88c6d90 30. ? @ 0x00007f46d88c6e40 31. _start @ 0x0000000017c9702e (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:06:34.832282 [ 58611 ] {} DiskLocal: Cannot gain read access of the disk directory: disk3_02961/ 2025.06.13 16:06:34.832319 [ 58611 ] {} DiskLocal: Disk disk3_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk3_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b10560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1045e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1a868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c949f32 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c94beb6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c95a742 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c94ce82 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9752ac 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4a3d3b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4a4316 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4a4f02 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47026d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7c1d3c 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c70d9e3 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d60c861 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d60c63f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d60c466 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5e6215 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4de44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e46517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b0ba7b 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e599b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb1ba8 29. ? @ 0x00007f46d88c6d90 30. ? @ 0x00007f46d88c6e40 31. _start @ 0x0000000017c9702e (version 25.3.3.20286.altinityantalya (altinity build)) 2025.06.13 16:06:34.832424 [ 58611 ] {} DiskLocal: Cannot gain read access of the disk directory: disk4_02961/ 2025.06.13 16:06:34.832457 [ 58611 ] {} DiskLocal: Disk disk4_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk4_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. std::exception::exception[abi:ne190107]() @ 0x0000000017e0ba94 1. ./build_docker/./base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000035997100 2. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000239e36cb 3. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000017cbf2f6 4. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b10560 5. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000023b1045e 6. ./build_docker/./src/Common/filesystemHelpers.cpp:324: FS::canRead(String const&) @ 0x0000000023b1a868 7. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002c949f32 8. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002c94beb6 9. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002c95a742 10. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002c94ce82 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9366cb 12. ./build_docker/./src/Disks/DiskFactory.cpp:48: DB::DiskFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x000000002c9363bc 13. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002c9752ac 14. ./build_docker/./src/Interpreters/Context.cpp:5058: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x000000002d4a3d3b 15. ./build_docker/./src/Interpreters/Context.cpp:5042: DB::Context::getDisksMap(std::lock_guard&) const @ 0x000000002d4a4316 16. ./build_docker/./src/Interpreters/Context.cpp:5037: DB::Context::getDisksMap() const @ 0x000000002d4a4f02 17. ./build_docker/./src/Interpreters/Context.cpp:1197: DB::Context::getDatabaseDisk() const @ 0x000000002d47026d 18. ./build_docker/./src/Databases/DatabasesCommon.cpp:329: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002c7c1d3c 19. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002c70d9e3 20. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x000000002d60c861 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107], std::allocator, 0>(std::allocator, char const* const&, std::shared_ptr&&) @ 0x000000002d60c63f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x000000002d60c466 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x000000002d5e6215 24. ./build_docker/./programs/local/LocalServer.cpp:859: DB::LocalServer::processConfig() @ 0x0000000023e4de44 25. ./build_docker/./programs/local/LocalServer.cpp:583: DB::LocalServer::main(std::vector> const&) @ 0x0000000023e46517 26. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x0000000035b0ba7b 27. ./build_docker/./programs/local/LocalServer.cpp:1088: mainEntryClickHouseLocal(int, char**) @ 0x0000000023e599b1 28. ./build_docker/./programs/main.cpp:295: main @ 0x0000000017cb1ba8 29. ? @ 0x00007f46d88c6d90 30. ? @ 0x00007f46d88c6e40 31. _start @ 0x0000000017c9702e (version 25.3.3.20286.altinityantalya (altinity build))